- abandon(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- abandon(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
- abandon(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- abandonStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
Handle any status changes that might be needed at the start of a state.
- abandonStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- AbstractApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
- AbstractApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Create a factory instance with the resource specified.
- AbstractBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
-
Base Configuration
class providing common structure for enabling and using Spring Batch.
- AbstractBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- AbstractCursorItemReader<T> - Class in org.springframework.batch.item.database
-
Abstract base class for any simple item reader that opens a database cursor and continually retrieves
the next row in the ResultSet.
- AbstractCursorItemReader() - Constructor for class org.springframework.batch.item.database.AbstractCursorItemReader
-
- AbstractFlowParser - Class in org.springframework.batch.core.configuration.xml
-
- AbstractFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- AbstractHibernateQueryProvider - Class in org.springframework.batch.item.database.orm
-
Abstract Hibernate Query Provider to serve as a base class for all
Hibernate Query
providers.
- AbstractHibernateQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
-
- AbstractItemCountingItemStreamItemReader<T> - Class in org.springframework.batch.item.support
-
Abstract superclass for
ItemReader
s that supports restart by storing
item count in the
ExecutionContext
(therefore requires item ordering
to be preserved between runs).
- AbstractItemCountingItemStreamItemReader() - Constructor for class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
- AbstractItemStreamItemReader<T> - Class in org.springframework.batch.item.support
-
- AbstractItemStreamItemReader() - Constructor for class org.springframework.batch.item.support.AbstractItemStreamItemReader
-
- AbstractItemStreamItemWriter<T> - Class in org.springframework.batch.item.support
-
- 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
-
- AbstractJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
- AbstractJobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
-
- AbstractJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- AbstractJobTests - Class in org.springframework.batch.test
-
- AbstractJobTests() - Constructor for class org.springframework.batch.test.AbstractJobTests
-
Deprecated.
- AbstractJpaQueryProvider - Class in org.springframework.batch.item.database.orm
-
Abstract JPA Query Provider to serve as a base class for all JPA
Query
providers.
- AbstractJpaQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
-
- AbstractLineTokenizer - Class in org.springframework.batch.item.file.transform
-
Abstract class handling common concerns of various
LineTokenizer
implementations such as dealing with names and actual construction of
FieldSet
- AbstractLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.AbstractLineTokenizer
-
- AbstractListenerFactoryBean<T> - Class in org.springframework.batch.core.listener
-
FactoryBean
implementation that builds a listener based on the
various lifecycle methods or annotations that are provided.
- AbstractListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- AbstractListenerParser - Class in org.springframework.batch.core.configuration.xml
-
- AbstractListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- AbstractMethodInvokingDelegator<T> - Class in org.springframework.batch.item.adapter
-
Superclass for delegating classes which dynamically call a custom method of
injected object.
- AbstractMethodInvokingDelegator() - Constructor for class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
-
- AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper - Exception in org.springframework.batch.item.adapter
-
Used to wrap a Throwable
(not an Exception
) thrown by a
reflectively-invoked delegate.
- AbstractNeo4jItemReader<T> - Class in org.springframework.batch.item.data
-
Restartable
ItemReader
that reads objects from the graph database Neo4j
via a paging technique.
- AbstractNeo4jItemReader() - Constructor for class org.springframework.batch.item.data.AbstractNeo4jItemReader
-
- 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
-
- AbstractPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
- AbstractSqlPagingQueryProvider - Class in org.springframework.batch.item.database.support
-
Abstract SQL Paging Query Provider to serve as a base class for all provided
SQL paging query providers.
- AbstractSqlPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
- AbstractState - Class in org.springframework.batch.core.job.flow.support.state
-
- AbstractState(String) - Constructor for class org.springframework.batch.core.job.flow.support.state.AbstractState
-
- AbstractStep - Class in org.springframework.batch.core.step
-
A
Step
implementation that provides common behavior to subclasses, including registering and calling
listeners.
- AbstractStep() - Constructor for class org.springframework.batch.core.step.AbstractStep
-
Default constructor.
- AbstractStep(String) - Constructor for class org.springframework.batch.core.step.AbstractStep
-
Convenient constructor for setting only the name property.
- AbstractStepParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <step/> elements inside a job.
- AbstractStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractStepParser
-
- AbstractTaskletStepBuilder<B extends AbstractTaskletStepBuilder<B>> - Class in org.springframework.batch.core.step.builder
-
Base class for step builders that want to build a
TaskletStep
.
- AbstractTaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
- add(Flow...) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
-
Add flows to the split, in addition to the current state already present in the parent builder.
- add(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- add(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- add(W) - Method in class org.springframework.batch.core.step.item.Chunk
-
Add the item to the chunk.
- add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
-
- add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
-
- add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
-
- addAll(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- addAll(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- addApplicationContextFactory(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
Add some factories to the set that will be used to load contexts and jobs.
- addDate(String, Date) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying Date
parameter for the given key.
- addDate(String, Date, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new Date
parameter for the given key.
- addDouble(String, Double) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying Double parameter for the given key.
- addDouble(String, Double, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new Double parameter for the given key.
- addExitDescription(String) - Method in class org.springframework.batch.core.ExitStatus
-
Add an exit description to an existing
ExitStatus
.
- addExitDescription(Throwable) - Method in class org.springframework.batch.core.ExitStatus
-
Extract the stack trace from the throwable provided and append it to
the exist description.
- addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
- addExitStatus(String) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- addExitStatus(String) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
-
- addFailureException(Throwable) - Method in class org.springframework.batch.core.JobExecution
-
Add the provided throwable to the failure exception list.
- addFailureException(Throwable) - Method in class org.springframework.batch.core.StepExecution
-
- ADDITIONAL_SHIPPING_INFO_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
-
- addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying Long parameter for the given key.
- addLong(String, Long, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new Long parameter for the given key.
- addParameter(String, JobParameter) - Method in class org.springframework.batch.core.JobParametersBuilder
-
- Address - Class in org.springframework.batch.sample.domain.order
-
- Address() - Constructor for class org.springframework.batch.sample.domain.order.Address
-
- ADDRESS_LINE1_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
-
- ADDRESS_LINE2_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
-
- ADDRESSEE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
-
- AddressFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
-
- AddressFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
-
- AddressFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
-
- AddressFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
-
- addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
-
Convenience method for adding a single step to the job.
- addStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- addStepExecutionListeners(List<JobExecutionListener>) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- addStepExecutionListeners(List<StepExecutionListener>) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
-
Add some step executions.
- addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- addStepExecutions(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
- addString(String, String) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying String parameter for the given key.
- addString(String, String, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new String parameter for the given key.
- after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
- after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
-
- after(RepeatContext, RepeatStatus) - Method in interface org.springframework.batch.repeat.RepeatListener
-
Called by the framework after each item has been processed, unless the
item processing results in an exception.
- after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
-
- after(JoinPoint, StepExecution) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
-
- AfterChunk - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a chunk is executed.
Expected signature: void afterChunk(ChunkContext context)
- afterChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback after the chunk is executed, outside the transaction.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.jsr.ChunkListenerAdapter
-
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
-
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Call the registered listeners in order, respecting and prioritizing those
that implement Ordered
.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- AfterChunkError - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a has failed and been
marked for rollback.
Expected signature: void afterFailedChunk(ChunkContext context)
- afterChunkError(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback after a chunk has been marked for rollback.
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.jsr.ChunkListenerAdapter
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- AfterJob - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a
Job
has completed.
- afterJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
-
Callback after completion of a job.
- afterJob(JobExecution) - Method in class org.springframework.batch.core.jsr.JobListenerAdapter
-
- afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
-
- AfterProcess - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is passed to an
ItemProcessor
Expected signature: void afterProcess(T item, S result)
- afterProcess(T, S) - Method in interface org.springframework.batch.core.ItemProcessListener
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.jsr.ItemProcessListenerAdapter
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterProcess(I, O) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterProcess(T, S) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- afterPropertiesSet() - Method in class org.springframework.batch.container.jms.BatchMessageListenerContainer
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Make sure the registry is set before use.
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
Check mandatory properties (name).
- afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.AbstractJob
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Check that there are no overlaps between required and optional keys.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.FlowStep
-
Ensure that the flow is set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Locate start state and pre-populate data structures needed for execution.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.SimpleStepHandler
-
Check mandatory properties (jobRepository).
- afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.job.JsrStepHandler
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
-
Ensure the required dependencies of a
JobRepository
have been
set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
Assert that mandatory properties are set (stepExecutionSplitter,
partitionHandler) and delegate top superclass.
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
Check mandatory properties (step name, job repository and partitioner).
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.AbstractStep
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.job.JobStep
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
Assert that the callable is set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
- afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
-
- 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.partition.MessageChannelPartitionHandler
-
- afterPropertiesSet() - Method in class org.springframework.batch.integration.step.DelegateStep
-
Check mandatory properties (delegate).
- afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
-
Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemReader
-
Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.Neo4jItemWriter
-
Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.RepositoryItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.RepositoryItemWriter
-
Check mandatory properties - there must be a repository.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Assert that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateItemWriter
-
Check mandatory properties - there must be a hibernateTemplate.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
-
Deprecated.
Check mandatory properties - there must be an SqlMapClient and a statementId.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
-
Deprecated.
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
-
Check mandatory properties - there must be a SimpleJdbcTemplate and an SQL statement plus a
parameter source.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
-
Assert that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaItemWriter
-
Check mandatory properties - there must be an entityManagerFactory.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
-
Assert that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
-
Assert that mandatory properties (lineAggregator) are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
-
Check that precisely one of type or prototype bean name is specified.
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.jms.JmsItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.KeyValueItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.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.validator.SpringValidator
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
-
- afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
-
Ensure that all required dependencies for the ItemReader to run are provided after all properties have been set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
-
Apply the provided properties to create a delegate handler.
- afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemListener
-
- afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemProcessor
-
- afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemReader
-
- afterPropertiesSet() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
-
Check mandatory properties (delegate).
- afterPropertiesSet() - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
-
- afterPropertiesSet() - Method in class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
-
- afterPropertiesSet() - Method in class org.springframework.batch.support.SystemPropertyInitializer
-
Sets the System property with the provided name and default value.
- afterPropertiesSet() - Method in class org.springframework.batch.test.DataSourceInitializer
-
- afterPropertiesSet() - Method in class org.springframework.batch.test.JobRepositoryTestUtils
-
- AfterRead - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is read from an
ItemReader
Expected signature: void afterRead(T item)
- afterRead(T) - Method in interface org.springframework.batch.core.ItemReadListener
-
- afterRead(T) - Method in class org.springframework.batch.core.jsr.ItemReadListenerAdapter
-
- afterRead(T) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterRead(I) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- afterRead(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterRead(T) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- afterRead(Long) - Method in class org.springframework.batch.sample.common.StagingItemListener
-
- AfterStep - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after a
Step
has completed.
- afterStep(StepExecution) - Method in class org.springframework.batch.core.jsr.StepListenerAdapter
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
Call the registered listeners in reverse order, respecting and
prioritizing those that implement Ordered
.
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- afterStep(StepExecution) - Method in class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
-
- afterStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
-
Give a listener a chance to modify the exit status from a step.
- afterStep(StepExecution) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
-
- afterStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemReader
-
- afterStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemWriter
-
- afterStep(StepExecution) - Method in class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
-
- afterTestClass(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
-
- afterTestClass(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
-
- afterTestMethod(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
-
- afterTestMethod(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
-
- AfterWrite - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is passed to an
ItemWriter
Expected signature: void afterWrite(
List
<? extends S> items)
- afterWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.jsr.ItemWriteListenerAdapter
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
-
Call the registered listeners in reverse order, respecting and
prioritising those that implement Ordered
.
- afterWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- aggregate(Collection<FlowExecution>) - Method in interface org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
-
- aggregate(Collection<FlowExecution>) - Method in class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
-
- aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.jsr.partition.support.JsrStepExecutionAggregator
-
- aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
-
- aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
Aggregates the input executions into the result
StepExecution
delegating to the delegate aggregator once the input has been refreshed
from the
JobExplorer
.
- aggregate(StepExecution, Collection<StepExecution>) - Method in interface org.springframework.batch.core.partition.support.StepExecutionAggregator
-
Take the inputs and aggregate, putting the aggregates into the result.
- aggregate(List<?>) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
-
- aggregate(T) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
-
Extract fields from the given item using the
FieldExtractor
and
then aggregate them.
- aggregate(T) - Method in interface org.springframework.batch.item.file.transform.LineAggregator
-
Create a string from the value provided.
- aggregate(T) - Method in class org.springframework.batch.item.file.transform.PassThroughLineAggregator
-
Simply convert to a String with toString().
- aggregate(Collection<T>) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
-
- aggregate(Order) - Method in class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
-
- AggregateItem<T> - Class in org.springframework.batch.sample.domain.multiline
-
A wrapper type for an item that is used by
AggregateItemReader
to
identify the start and end of an aggregate record.
- AggregateItem(T) - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItem
-
- AggregateItem(boolean, boolean) - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItem
-
- AggregateItemFieldSetMapper<T> - Class in org.springframework.batch.sample.domain.multiline
-
- AggregateItemFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
-
- AggregateItemReader<T> - Class in org.springframework.batch.sample.domain.multiline
-
An
ItemReader
that delivers a list as its item, storing up objects
from the injected
ItemReader
until they are ready to be packed out as
a collection.
- AggregateItemReader() - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItemReader
-
- aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
Provide a step execution aggregator for aggregating partitioned step executions into a single result for the
PartitionStep
itself.
- Alignment - Enum in org.springframework.batch.item.file.transform
-
- allowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- AlwaysSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
-
Implementation of the
SkipPolicy
interface that
will always return that an item should be skipped.
- AlwaysSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
-
- AmqpItemReader<T> - Class in org.springframework.batch.item.amqp
-
AMQP
ItemReader
implementation using an
AmqpTemplate
to
receive and/or convert messages.
- AmqpItemReader(AmqpTemplate) - Constructor for class org.springframework.batch.item.amqp.AmqpItemReader
-
- AmqpItemWriter<T> - Class in org.springframework.batch.item.amqp
-
AMQP
ItemWriter
implementation using an
AmqpTemplate
to
send messages.
- AmqpItemWriter(AmqpTemplate) - Constructor for class org.springframework.batch.item.amqp.AmqpItemWriter
-
- AmqpMessageProducer - Class in org.springframework.batch.sample.rabbitmq.amqp
-
Simple producer class that sends String
messages to the configured queue to be processed.
- and(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
-
Create a new
ExitStatus
with a logical combination of the exit
code, and a concatenation of the descriptions.
- and(boolean) - Method in enum org.springframework.batch.repeat.RepeatStatus
-
- AnnotationMethodResolver - Class in org.springframework.batch.support
-
MethodResolver implementation that finds a single Method on the
given Class that contains the specified annotation type.
- AnnotationMethodResolver(Class<? extends Annotation>) - Constructor for class org.springframework.batch.support.AnnotationMethodResolver
-
Create a MethodResolver for the specified Method-level annotation type
- ApplicationContextFactory - Interface in org.springframework.batch.core.configuration.support
-
Factory for the creation of ApplicationContext
s.
- ApplicationContextJobFactory - Class in org.springframework.batch.core.configuration.support
-
A
JobFactory
that creates its own
ApplicationContext
and
pulls a bean out when asked to create a
Job
.
- ApplicationContextJobFactory(String, ApplicationContextFactory) - Constructor for class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
- apply(StepContribution) - Method in class org.springframework.batch.core.StepExecution
-
On successful execution just before a chunk commit, this method should be
called.
- applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
- applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- applyListenerScope(String, BeanDefinitionRegistry) - Method in class org.springframework.batch.core.jsr.configuration.xml.ListenerParser
-
- applyStatementSettings(PreparedStatement) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Prepare the given JDBC Statement (or PreparedStatement or
CallableStatement), applying statement settings such as fetch size, max
rows, and query timeout.
- ArrayFieldSetMapper - Class in org.springframework.batch.item.file.mapping
-
A basic array mapper, returning the values backing a fieldset.
- ArrayFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.ArrayFieldSetMapper
-
- AssertFile - Class in org.springframework.batch.test
-
This class can be used to assert that two files are the same.
- AssertFile() - Constructor for class org.springframework.batch.test.AssertFile
-
- assertFileEquals(File, File) - Static method in class org.springframework.batch.test.AssertFile
-
- assertFileEquals(Resource, Resource) - Static method in class org.springframework.batch.test.AssertFile
-
- assertLineCount(int, File) - Static method in class org.springframework.batch.test.AssertFile
-
- assertLineCount(int, Resource) - Static method in class org.springframework.batch.test.AssertFile
-
- AsynchronousFailureException - Exception in org.springframework.batch.integration.chunk
-
Exception indicating that a failure or early completion condition was
detected in a remote worker.
- AsynchronousFailureException(String, Throwable) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
-
- AsynchronousFailureException(String) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
-
- 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
-
- backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Provide a backoff policy to prevent items being retried immediately (e.g.
- BaseContextListFactoryBean - Class in org.springframework.batch.core.jsr.configuration.support
-
A simple factory bean that consolidates the list of locations to look for the base context for the JSR-352
functionality
- BaseContextListFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
-
- BatchArtifactType - Enum in org.springframework.batch.core.jsr.configuration.support
-
Enum to identify batch artifact types.
- BatchConfigurationException - Exception in org.springframework.batch.core.configuration
-
Represents an error has occured in the configuration of base batch
infrastructure (creation of a
JobRepository
for example.
- BatchConfigurationException(Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
-
- BatchConfigurationSelector - Class in org.springframework.batch.core.configuration.annotation
-
Base Configuration
class providing common structure for enabling and using Spring Batch.
- BatchConfigurationSelector() - Constructor for class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
-
- BatchConfigurer - Interface in org.springframework.batch.core.configuration.annotation
-
Strategy interface for users to provide as a factory for custom components needed by a Batch system.
- BatchIntegrationNamespaceHandler - Class in org.springframework.batch.integration.config.xml
-
The namespace handler for the Spring Batch Integration namespace.
- BatchIntegrationNamespaceHandler() - Constructor for class org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
-
- BatchletAdapter - Class in org.springframework.batch.core.jsr.step.batchlet
-
- BatchletAdapter(Batchlet) - Constructor for class org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
-
- BatchletParser - Class in org.springframework.batch.core.jsr.configuration.xml
-
Parser for the <batchlet /> tag defined in JSR-352.
- BatchletParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.BatchletParser
-
- BatchletStep - Class in org.springframework.batch.core.jsr.step
-
Special sub class of the
TaskletStep
for use with JSR-352 jobs.
- BatchletStep(String, BatchPropertyContext) - Constructor for class org.springframework.batch.core.jsr.step.BatchletStep
-
- BatchMessageListenerContainer - Class in org.springframework.batch.container.jms
-
Message listener container adapted for intercepting the message reception
with advice provided through configuration.
To enable batching of messages in a single transaction, use the
TransactionInterceptor
and the
RepeatOperationsInterceptor
in
the advice chain (with or without a transaction manager set in the base
class).
- BatchMessageListenerContainer() - Constructor for class org.springframework.batch.container.jms.BatchMessageListenerContainer
-
- BatchMessageListenerContainer.ContainerDelegate - Interface in org.springframework.batch.container.jms
-
- BatchParser - Class in org.springframework.batch.core.jsr.configuration.xml
-
Parser used to parse the batch.xml file as defined in JSR-352.
- BatchParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.BatchParser
-
- BatchPropertyBeanPostProcessor - Class in org.springframework.batch.core.jsr.launch.support
-
BeanPostProcessor
implementation used to inject JSR-352 String properties into batch artifact fields
that are marked with the BatchProperty
annotation.
- BatchPropertyBeanPostProcessor() - Constructor for class org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
-
- BatchPropertyContext - Class in org.springframework.batch.core.jsr.configuration.support
-
Context object to hold parsed JSR-352 batch properties, mapping properties to beans /
"batch artifacts".
- BatchPropertyContext() - Constructor for class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
-
- BatchRetryTemplate - Class in org.springframework.batch.core.step.item
-
A special purpose retry template that deals specifically with multi-valued
stateful retry.
- BatchRetryTemplate() - Constructor for class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- BatchScopeSupport - Class in org.springframework.batch.core.scope
-
ScopeSupport.
- BatchScopeSupport() - Constructor for class org.springframework.batch.core.scope.BatchScopeSupport
-
- BatchScopeSupport.Scopifier - Class in org.springframework.batch.core.scope
-
Helper class to scan a bean definition hierarchy and force the use of
auto-proxy for step scoped beans.
- BatchStatus - Enum in org.springframework.batch.core
-
Enumeration representing the status of a an Execution.
- BeanDefinitionUtils - Class in org.springframework.batch.core.configuration.xml
-
- BeanDefinitionUtils() - Constructor for class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
-
- BeanFactoryStepLocator - Class in org.springframework.batch.integration.partition
-
A
StepLocator
implementation that just looks in its enclosing bean
factory for components of type
Step
.
- BeanFactoryStepLocator() - Constructor for class org.springframework.batch.integration.partition.BeanFactoryStepLocator
-
- BeanPropertyItemSqlParameterSourceProvider<T> - Class in org.springframework.batch.item.database
-
A convenient implementation for providing BeanPropertySqlParameterSource when the item has JavaBean properties
that correspond to names used for parameters in the SQL statement.
- BeanPropertyItemSqlParameterSourceProvider() - Constructor for class org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
-
- BeanWrapperFieldExtractor<T> - Class in org.springframework.batch.item.file.transform
-
This is a field extractor for a java bean.
- BeanWrapperFieldExtractor() - Constructor for class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
-
- BeanWrapperFieldSetMapper<T> - Class in org.springframework.batch.item.file.mapping
-
- BeanWrapperFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
-
- before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
- before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
-
- before(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
-
Called by the framework before each batch item.
- before(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
-
- before(JoinPoint, StepExecution) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
-
- BeforeChunk - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called before a chunk is executed.
- beforeChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback before the chunk is executed, but inside the transaction.
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.jsr.ChunkListenerAdapter
-
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
-
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Call the registered listeners in reverse order.
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- BeforeJob - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called before a
Job
is executed, which comes
after a
JobExecution
is created and persisted, but before the first
Step
is executed.
- beforeJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
-
Callback before a job executes.
- beforeJob(JobExecution) - Method in class org.springframework.batch.core.jsr.JobListenerAdapter
-
- beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
Call the registered listeners in order, respecting and prioritising those
that implement Ordered
.
- beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
-
- BeforeProcess - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called before an item is passed to an
ItemProcessor
Expected signature: void beforeProcess(T item)
- beforeProcess(T) - Method in interface org.springframework.batch.core.ItemProcessListener
-
- beforeProcess(T) - Method in class org.springframework.batch.core.jsr.ItemProcessListenerAdapter
-
- beforeProcess(T) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
-
Call the registered listeners in order, respecting and prioritising those
that implement Ordered
.
- beforeProcess(I) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- beforeProcess(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- beforeProcess(T) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- BeforeRead - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called before an item is read from an
ItemReader
Expected signature: void beforeRead()
- beforeRead() - Method in interface org.springframework.batch.core.ItemReadListener
-
- beforeRead() - Method in class org.springframework.batch.core.jsr.ItemReadListenerAdapter
-
- beforeRead() - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
-
Call the registered listeners in order, respecting and prioritising those
that implement Ordered
.
- beforeRead() - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- beforeRead() - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- beforeRead() - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- BeforeStep - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called before a
Step
is executed, which comes
after a
StepExecution
is created and persisted, but before the first
item is read.
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.jsr.StepListenerAdapter
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
Call the registered listeners in order, respecting and prioritizing those
that implement Ordered
.
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
-
- 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(StepExecution) - Method in class org.springframework.batch.sample.common.InfiniteLoopWriter
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemReader
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemWriter
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
-
- beforeStep(StepExecution) - Method in class org.springframework.batch.sample.support.SummaryFooterCallback
-
- beforeTestClass(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
-
- beforeTestClass(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
-
- beforeTestMethod(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
-
- beforeTestMethod(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
-
- BeforeWrite - Annotation Type in org.springframework.batch.core.annotation
-
Marks a method to be called before an item is passed to an
ItemWriter
Expected signature: void beforeWrite(
List
<? extends S> items)
- beforeWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
-
- beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.jsr.ItemWriteListenerAdapter
-
- beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
-
Call the registered listeners in order, respecting and prioritising those
that implement Ordered
.
- beforeWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
-
- beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
-
- beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
-
- begin(T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
Make a copy of the target that can be used inside a transaction to
isolate changes from the original.
- BillingFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
-
- BillingFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
-
- BillingInfo - Class in org.springframework.batch.sample.domain.order
-
- BillingInfo() - Constructor for class org.springframework.batch.sample.domain.order.BillingInfo
-
- BillingInfoFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
-
- BillingInfoFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
-
- bind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
-
- BufferedReaderFactory - Interface in org.springframework.batch.item.file
-
A factory strategy for custom extensions of BufferedReader
allowing
customisation of the standard behaviour of the java.io
variety.
- build() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Validate the current state of the builder and build a flow.
- build() - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Build a job that executes the flow provided, normally composed of other steps.
- build() - Method in class org.springframework.batch.core.job.builder.JobFlowBuilder
-
Build a flow and inject it into the parent builder.
- build() - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
-
- build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrBatchletStepBuilder
-
Build the step from the components collected by the fluent setters.
- build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
-
Build the step from the components collected by the fluent setters.
- build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
-
- build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
-
Build the step from the components collected by the fluent setters.
- build() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Build the step from the components collected by the fluent setters.
- build() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- build() - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
-
Build a step that executes the flow provided, normally composed of other steps.
- build() - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
-
Build a step from the job provided.
- build() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- build() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Build a step with the reader, writer, processor as provided.
- buildSortClause(AbstractSqlPagingQueryProvider) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generates ORDER BY attributes based on the sort keys.
- buildSortClause(Map<String, Order>) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generates ORDER BY attributes based on the sort keys.
- buildSortConditions(AbstractSqlPagingQueryProvider, StringBuilder) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Appends the where conditions required to query for the subsequent pages.
- CallableTaskletAdapter - Class in org.springframework.batch.core.step.tasklet
-
- CallableTaskletAdapter() - Constructor for class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
- canContinue(RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
-
Check return value from batch operation.
- canRetry(RetryContext) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- checkInterrupted(StepExecution) - Method in interface org.springframework.batch.core.step.StepInterruptionPolicy
-
- checkInterrupted(StepExecution) - Method in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
-
Returns if the current job lifecycle has been interrupted by checking if
the current thread is interrupted.
- CheckpointAlgorithmAdapter - Class in org.springframework.batch.jsr.repeat
-
Wrapper for the CheckpointAlgorithm
to be used via the rest
of the framework.
- CheckpointAlgorithmAdapter(CheckpointAlgorithm) - Constructor for class org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
-
- CheckpointSupport - Class in org.springframework.batch.jsr.item
-
Provides support for JSR-352 checkpointing.
- CheckpointSupport(String) - Constructor for class org.springframework.batch.jsr.item.CheckpointSupport
-
- Child - Class in org.springframework.batch.sample.domain.person
-
- Child() - Constructor for class org.springframework.batch.sample.domain.person.Child
-
- chunk(int) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Sets the chunk size or commit interval for this step.
- chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Sets a completion policy for the chunk processing.
- chunk(int) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Build a step that processes items in chunks with the size provided.
- chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Build a step that processes items in chunks with the completion policy provided.
- Chunk<W> - Class in org.springframework.batch.core.step.item
-
Encapsulation of a list of items to be processed and possibly a list of
failed items to be skipped.
- Chunk() - Constructor for class org.springframework.batch.core.step.item.Chunk
-
- Chunk(Collection<? extends W>) - Constructor for class org.springframework.batch.core.step.item.Chunk
-
- Chunk(Collection<? extends W>, List<SkipWrapper<W>>) - Constructor for class org.springframework.batch.core.step.item.Chunk
-
- Chunk.ChunkIterator - Class in org.springframework.batch.core.step.item
-
- ChunkContext - Class in org.springframework.batch.core.scope.context
-
Context object for weakly typed data stored for the duration of a chunk
(usually a group of items processed together in a transaction).
- ChunkContext(StepContext) - Constructor for class org.springframework.batch.core.scope.context.ChunkContext
-
- ChunkElementParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <chunk/> element inside a step.
- ChunkElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.ChunkElementParser
-
- ChunkHandler<T> - Interface in org.springframework.batch.integration.chunk
-
Interface for a remote worker in the Remote Chunking pattern.
- ChunkIterator(List<W>) - Constructor for class org.springframework.batch.core.step.item.Chunk.ChunkIterator
-
- ChunkListener - Interface in org.springframework.batch.core
-
Listener interface for the lifecycle of a chunk.
- ChunkListenerAdapter - Class in org.springframework.batch.core.jsr
-
- ChunkListenerAdapter(ChunkListener) - Constructor for class org.springframework.batch.core.jsr.ChunkListenerAdapter
-
- chunkListeners - Variable in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
- ChunkListenerSupport - Class in org.springframework.batch.core.listener
-
- ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
-
- ChunkMessageChannelItemWriter<T> - Class in org.springframework.batch.integration.chunk
-
- ChunkMessageChannelItemWriter() - Constructor for class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
-
- ChunkMonitor - Class in org.springframework.batch.core.step.item
-
Manage the offset data between the last successful commit and updates made to
an input chunk.
- ChunkMonitor() - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor
-
- ChunkMonitor.ChunkMonitorData - Class in org.springframework.batch.core.step.item
-
- ChunkMonitorData(int, int) - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
-
- chunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Instead of a
chunk size
or
completion policy
you can provide
a complete repeat operations instance that handles the iteration over the item reader.
- ChunkOrientedTasklet<I> - Class in org.springframework.batch.core.step.item
-
A
Tasklet
implementing variations on read-process-write item
handling.
- ChunkOrientedTasklet(ChunkProvider<I>, ChunkProcessor<I>) - Constructor for class org.springframework.batch.core.step.item.ChunkOrientedTasklet
-
- ChunkParser - Class in org.springframework.batch.core.jsr.configuration.xml
-
Parser for the <chunk /> element as specified in JSR-352.
- ChunkParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.ChunkParser
-
- ChunkProcessor<I> - Interface in org.springframework.batch.core.step.item
-
Interface defined for processing
Chunk
s.
- ChunkProcessorChunkHandler<S> - Class in org.springframework.batch.integration.chunk
-
- ChunkProcessorChunkHandler() - Constructor for class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
-
- ChunkProvider<T> - Interface in org.springframework.batch.core.step.item
-
- ChunkRequest<T> - Class in org.springframework.batch.integration.chunk
-
Encapsulation of a chunk of items to be processed remotely as part of a step
execution.
- ChunkRequest(int, Collection<? extends T>, long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkRequest
-
- ChunkResponse - Class in org.springframework.batch.integration.chunk
-
Encapsulates a response to processing a chunk of items, summarising the result as a
StepContribution
.
- ChunkResponse(int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
-
- ChunkResponse(boolean, int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
-
- ChunkResponse(boolean, int, Long, StepContribution, String) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
-
- ChunkResponse(ChunkResponse, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
-
- ChunkResponse(boolean, int, Long, StepContribution, String, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
-
- chunkSize - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
-
- CITY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
-
- Classifier - Annotation Type in org.springframework.batch.support.annotation
-
Mark a method as capable of classifying its input to an instance of its
output.
- 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
-
- ClassifierCompositeItemWriter<T> - Class in org.springframework.batch.item.support
-
Calls one of a collection of ItemWriters for each item, based on a router
pattern implemented through the provided Classifier
.
- ClassifierCompositeItemWriter() - Constructor for class org.springframework.batch.item.support.ClassifierCompositeItemWriter
-
- ClassPathXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
- ClassPathXmlApplicationContextFactory(Resource) - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
-
Deprecated.
Create an application context factory for the resource specified.
- ClasspathXmlApplicationContextsFactoryBean - Class in org.springframework.batch.core.configuration.support
-
- ClasspathXmlApplicationContextsFactoryBean() - Constructor for class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
- ClassPathXmlJobRegistry - Class in org.springframework.batch.core.configuration.support
-
- ClassPathXmlJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
-
Deprecated.
- cleanupOnClose() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
- cleanupOnClose() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
-
Close the cursor and database connection.
- cleanupOnClose() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
-
Close the cursor and database connection.
- clear() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Unregister all the jobs and close all the contexts created by this
loader.
- clear() - Method in interface org.springframework.batch.core.configuration.support.JobLoader
-
Unregister all the jobs and close all the contexts created by this
loader.
- clear() - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- clear() - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- clear() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- clear() - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- clear() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
Convenience method to clear all the map DAOs globally, removing all
entities.
- clear() - Method in class org.springframework.batch.core.step.item.Chunk
-
Clear the items down to signal that we are done.
- clear() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
-
Clear the session if stateful.
- clear() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
-
Clear the current context at the end of a batch - should only be used by
RepeatOperations
implementations.
- clear() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
-
- clear() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
-
- clearDirtyFlag() - Method in class org.springframework.batch.item.ExecutionContext
-
Clears the dirty flag.
- clearSkips() - Method in class org.springframework.batch.core.step.item.Chunk
-
Clear only the skips list.
- close(FlowExecution) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
Chance to clean up resources at the end of a flow (whether it completed
successfully or not).
- close(FlowExecution) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- close() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
-
Used to remove the JobContext
for the current thread.
- close() - Method in class org.springframework.batch.core.scope.context.JobContext
-
Clean up the context at the end of a step execution.
- close() - Static method in class org.springframework.batch.core.scope.context.JobSynchronizationManager
-
- 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
-
- close() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
- close(C) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
- close(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
-
Extension point for subclasses to provide callbacks to their collaborators at the end of a step (right at the end
of the finally block), to close or release resources.
- close() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
-
- close(RetryContext, RetryCallback<T, E>, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
-
If retry is exhausted set up some state in the context that can be used
to signal that the exception should be handled.
- close(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
- close() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
-
- close() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
-
Close the open session (stateful or otherwise).
- close() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
-
- close() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
-
- close() - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
-
- close() - Method in interface org.springframework.batch.item.ItemStream
-
If any resources are needed for the stream to operate they need to be destroyed here.
- close() - Method in class org.springframework.batch.item.ItemStreamSupport
-
No-op.
- close() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
- close() - Method in class org.springframework.batch.item.support.CompositeItemStream
-
Broadcast the call to close.
- close() - Method in class org.springframework.batch.item.support.CompositeItemWriter
-
- close() - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
-
If the delegate is an
ItemStream
, just pass the call on,
otherwise reset the peek cache.
- close() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
-
- close() - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
-
- close() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Flush and close the output source.
- close() - Method in class org.springframework.batch.jsr.item.CheckpointSupport
-
- close() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
-
- close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
- close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
-
- close() - Method in interface org.springframework.batch.repeat.RepeatContext
-
Allow resources to be cleared, especially in destruction callbacks.
- close(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
-
Called once at the end of a complete batch, after normal or abnormal
completion (i.e.
- close() - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
-
- close(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
-
- close() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
-
- ColumnMapItemPreparedStatementSetter - Class in org.springframework.batch.item.database.support
-
Implementation of the
ItemPreparedStatementSetter
interface that assumes all
keys are contained within a
Map
with the column name as the key.
- ColumnMapItemPreparedStatementSetter() - Constructor for class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
-
- ColumnRangePartitioner - Class in org.springframework.batch.sample.common
-
Simple minded partitioner for a range of values of a column in a database
table.
- ColumnRangePartitioner() - Constructor for class org.springframework.batch.sample.common.ColumnRangePartitioner
-
- CommandLineJobRunner - Class in org.springframework.batch.core.launch.support
-
Basic launcher for starting jobs from the command line.
- CommandLineJobRunner() - Constructor for class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
- commit(T, T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
Take the working copy state and commit it back to the original target.
- 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
-
- CommonsLoggingInvalidCustomerLogger - Class in org.springframework.batch.sample.domain.trade.internal
-
- CommonsLoggingInvalidCustomerLogger() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
-
- 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
-
- COMPANY_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
-
- 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
-
- 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
-
- CompletionPolicySupport() - Constructor for class org.springframework.batch.repeat.policy.CompletionPolicySupport
-
- CompositeBatchContext(RepeatContext, List<RepeatContext>) - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
-
- CompositeChunkListener - Class in org.springframework.batch.core.listener
-
- CompositeChunkListener() - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
-
- CompositeCompletionPolicy - Class in org.springframework.batch.repeat.policy
-
Composite policy that loops through a list of delegate policies and answers
calls by a consensus.
- CompositeCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
-
- CompositeCompletionPolicy.CompositeBatchContext - Class in org.springframework.batch.repeat.policy
-
Composite context that knows about the policies and contexts is was
created with.
- CompositeCustomerUpdateLineTokenizer - Class in org.springframework.batch.sample.domain.trade
-
Composite
LineTokenizer
that delegates the tokenization of a line to one of two potential
tokenizers.
- CompositeCustomerUpdateLineTokenizer() - Constructor for class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
-
- CompositeExceptionHandler - Class in org.springframework.batch.repeat.exception
-
- CompositeExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.CompositeExceptionHandler
-
- CompositeItemProcessListener<T,S> - Class in org.springframework.batch.core.listener
-
- CompositeItemProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemProcessListener
-
- CompositeItemProcessor<I,O> - Class in org.springframework.batch.item.support
-
Composite
ItemProcessor
that passes the item through a sequence of
injected
ItemTransformer
s (return value of previous
transformation is the entry value of the next).
Note the user is responsible for injecting a chain of
ItemProcessor
s
that conforms to declared input and output types.
- CompositeItemProcessor() - Constructor for class org.springframework.batch.item.support.CompositeItemProcessor
-
- CompositeItemReadListener<T> - Class in org.springframework.batch.core.listener
-
- CompositeItemReadListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemReadListener
-
- CompositeItemStream - Class in org.springframework.batch.item.support
-
Simple
ItemStream
that delegates to a list of other streams.
- CompositeItemStream() - Constructor for class org.springframework.batch.item.support.CompositeItemStream
-
- CompositeItemWriteListener<S> - Class in org.springframework.batch.core.listener
-
- CompositeItemWriteListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemWriteListener
-
- CompositeItemWriter<T> - Class in org.springframework.batch.item.support
-
Calls a collection of
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
-
- CompositeJobExecutionListener - Class in org.springframework.batch.core.listener
-
- CompositeJobExecutionListener() - Constructor for class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
- CompositeJobParametersValidator - Class in org.springframework.batch.core.job
-
Composite
JobParametersValidator
that passes the job parameters through a sequence of
injected
JobParametersValidator
s
- CompositeJobParametersValidator() - Constructor for class org.springframework.batch.core.job.CompositeJobParametersValidator
-
- CompositeRepeatListener - Class in org.springframework.batch.repeat.listener
-
- CompositeRepeatListener() - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
- CompositeRetryProcessListener - Class in org.springframework.batch.core.listener
-
Composite class holding RetryProcessListener
's.
- CompositeRetryProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeRetryProcessListener
-
- CompositeRetryReadListener - Class in org.springframework.batch.core.listener
-
Composite class holding RetryReadListener
's.
- CompositeRetryReadListener() - Constructor for class org.springframework.batch.core.listener.CompositeRetryReadListener
-
- CompositeRetryWriteListener - Class in org.springframework.batch.core.listener
-
Composite class holding RetryWriteListener
's.
- CompositeRetryWriteListener() - Constructor for class org.springframework.batch.core.listener.CompositeRetryWriteListener
-
- CompositeSkipListener<T,S> - Class in org.springframework.batch.core.listener
-
- CompositeSkipListener() - Constructor for class org.springframework.batch.core.listener.CompositeSkipListener
-
- CompositeSkipPolicy - Class in org.springframework.batch.core.step.skip
-
- CompositeSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.CompositeSkipPolicy
-
- CompositeSkipPolicy(SkipPolicy[]) - Constructor for class org.springframework.batch.core.step.skip.CompositeSkipPolicy
-
- CompositeStepExecutionListener - Class in org.springframework.batch.core.listener
-
- CompositeStepExecutionListener() - Constructor for class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
- concurrent() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to determine if the step is concurrent.
- ConfigurableSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
-
Maps exit codes to
ExitStatus
according to injected map.
- ConfigurableSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
-
- containsKey(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Indicates whether or not a key is represented in this context.
- containsValue(Object) - Method in class org.springframework.batch.item.ExecutionContext
-
Indicates whether or not a value is represented in this context.
- continueIf(boolean) - Static method in enum org.springframework.batch.repeat.RepeatStatus
-
- ConversionException - Exception in org.springframework.batch.item.file.transform
-
- ConversionException(String) - Constructor for exception org.springframework.batch.item.file.transform.ConversionException
-
- convert(V) - Method in class org.springframework.batch.item.SpELItemKeyMapper
-
- CoreNamespaceHandler - Class in org.springframework.batch.core.configuration.xml
-
- CoreNamespaceHandler() - Constructor for class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
-
- CoreNamespacePostProcessor - Class in org.springframework.batch.core.configuration.xml
-
Post-process jobs and steps defined using the batch namespace to inject
dependencies.
- CoreNamespacePostProcessor() - Constructor for class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
-
- CoreNamespaceUtils - Class in org.springframework.batch.core.configuration.xml
-
Utility methods used in parsing of the batch core namespace
- CoreNamespaceUtils() - Constructor for class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
-
- COUNT - Static variable in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
Session key for global counter.
- CountingBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
-
- CountingCompletionPolicy - Class in org.springframework.batch.repeat.policy
-
Abstract base class for policies that need to count the number of occurrences
of some event (e.g.
- CountingCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
- CountingCompletionPolicy.CountingBatchContext - Class in org.springframework.batch.repeat.policy
-
- countParameterPlaceholders(String, List<String>) - Static method in class org.springframework.batch.item.database.JdbcParameterUtils
-
Count the occurrences of the character placeholder in an SQL string
sql
.
- COUNTRY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
-
- create(Resource, String) - Method in interface org.springframework.batch.item.file.BufferedReaderFactory
-
Create a BufferedReader
for reading String items from the
provided resource.
- create(Resource, String) - Method in class org.springframework.batch.item.file.DefaultBufferedReaderFactory
-
- create(Resource, String) - Method in class org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
-
- create(String[], String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
Create a FieldSet with named tokens.
- create(String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
Create a FieldSet with anonymous tokens.
- create(String[], String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
-
Create a FieldSet with named tokens.
- create(String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
-
Create a FieldSet with anonymous tokens.
- createAppendOnlyTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createAppendOnlyTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createAppendOnlyTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Creates an ApplicationContext
from the provided path.
- createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
- createApplicationContext() - Method in interface org.springframework.batch.core.configuration.support.ApplicationContextFactory
-
- createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
-
- createBinder(Object) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
-
Create a binder for the target object.
- createBuilder(String) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
- createBuilder(String) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- createChunkOperations() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- createChunkProcessor() - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
-
- createChunkProcessor() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- createChunkProvider() - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
-
- createChunkProvider() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- createEndStateTransition(State) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
- createEndStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
- createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
- createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- createFaultTolerantStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- createFlowStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- createInternalState(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
-
Create an internal state object that is used to store data needed
internally in the scope of an iteration.
- createInternalState(RepeatContext) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
-
- createJob() - Method in interface org.springframework.batch.core.configuration.JobFactory
-
- createJob() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
Create an ApplicationContext
from the factory provided and pull
out a bean with the name given during initialization.
- createJob() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
-
Just return the instance passed in on initialization.
- createJobExecution(JobInstance, JobParameters, String) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Create a new
JobExecution
based upon the
JobInstance
it's associated
with, the
JobParameters
used to execute it with and the location of the configuration
file that defines the job.
- createJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- createJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- createJobExecution(JobInstance, JobParameters, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- createJobExecution() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobExecution(Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobExecution(String, Long, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobExecution(String, Long, Long, String) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobExecution(String, Long, Long, JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
- createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- createJobExecutions(String, String[], int) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
-
Use the
JobRepository
to create some
JobExecution
instances each with the given job name and each having step executions
with the given step names.
- createJobExecutions(int) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
-
- createJobExecutionWithStepExecutions(Long, Collection<String>) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
JobExecution
with the parameters provided with attached
step executions.
- createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
In this JDBC implementation a job id is obtained by asking the
jobIncrementer (which is likely a sequence) for the next long value, and
then passing the Id and parameter values into an INSERT statement.
- createJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Create a JobInstance with given name and parameters.
- createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- createJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Create a new
JobInstance
with the name and job parameters provided.
- createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- createJobInstance(String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobInstance() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
- createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- createJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- createJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- createNewContext(E, BatchPropertyContext) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
- createNewFile(File) - Static method in class org.springframework.batch.item.util.FileUtils
-
Create a new file if it doesn't already exist.
- createNewStepState(State, String, String) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
Provides an extension point to provide alternative
StepState
implementations within a
SimpleFlow
- createNewStepState(State, String, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrFlowFactoryBean
-
- createOutputNameFromInput(StepExecution) - Method in class org.springframework.batch.sample.common.OutputFileListener
-
- createPartitionStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- createPartitionStep() - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
-
- createQuery() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
-
Open appropriate type of hibernate session and create the query.
- createQuery() - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
-
Create an SQLQuery
from the session provided (preferring
stateless if both are available).
- createQuery() - Method in interface org.springframework.batch.item.database.orm.HibernateQueryProvider
-
Create the query object which type will be determined by the underline
implementation (e.g.
- createQuery() - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
-
- createQuery() - Method in interface org.springframework.batch.item.database.orm.JpaQueryProvider
-
Create the query object.
- createRetryOperations() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- createScopedProxy(String, BeanDefinition, BeanDefinitionRegistry, boolean) - Static method in class org.springframework.batch.core.scope.BatchScopeSupport
-
Wrap a target bean definition in a proxy that defers initialization until
after the
StepContext
is available.
- createSemaphore() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Extension point mainly for test purposes so that the behaviour of the
lock can be manipulated to simulate various pathologies.
- createSimpleStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- createSkipPolicy() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- createSqlParameterSource(T) - Method in class org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
-
Provide parameter values in an BeanPropertySqlParameterSource
based on values from
the provided item.
- createSqlParameterSource(T) - Method in interface org.springframework.batch.item.database.ItemSqlParameterSourceProvider
-
Provide parameter values in an SqlParameterSource
based on values from
the provided item.
- createState(List<?>) - Static method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- createState(List<?>, Classifier<? super Throwable, Boolean>) - Static method in class org.springframework.batch.core.step.item.BatchRetryTemplate
-
- createStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Create a new state
StateTransition
specification with a wildcard
pattern that matches all outcomes.
- createStateTransition(State, String, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
- 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
-
- createStepExecution(String) - Method in class org.springframework.batch.core.JobExecution
-
Register a step execution with the current job execution.
- createStepExecution() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createStepExecution(String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createStepExecution(JobExecution, String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createStepExecution(JobParameters, ExecutionContext) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createStepExecution(JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createStepExecution(ExecutionContext) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
- createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
- createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
-
- createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- createTask(Step, StepExecution) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
-
Creates the task executing the given step in the context of the given execution.
- createTask(Step, StepExecution) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
Creates the task executing the given step in the context of the given execution.
- createTasklet() - Method in class org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
-
- createTasklet() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
- createTasklet() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Create a new chunk oriented tasklet with reader, writer and processor as provided.
- createTasklet() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- createTasklet() - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
-
- createTaskletStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- createTaskletStep() - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
-
- createTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createTransactionalList(List<T>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createTransactionalMap(Map<K, V>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createTransactionalSet(Set<T>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
- createTransition(FlowExecutionStatus, String, String, String, BeanDefinition, ParserContext, boolean) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- createTransition(FlowExecutionStatus, String, String, String, String, BeanDefinition, ParserContext, boolean) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
-
- createXmlEventFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the event factory.
- createXmlEventWriter(XMLOutputFactory, Writer) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the writer.
- createXmlInputFactory() - Static method in class org.springframework.batch.item.xml.StaxUtils
-
- createXmlOutputFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the factory.
- CREDIT_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
-
- CREDIT_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
-
- Customer - Class in org.springframework.batch.sample.domain.order
-
- Customer() - Constructor for class org.springframework.batch.sample.domain.order.Customer
-
- Customer - Class in org.springframework.batch.sample.domain.order.internal.xml
-
An XML customer.
- Customer() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Customer
-
- CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
-
- CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
-
- CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
-
- CustomerCredit - Class in org.springframework.batch.sample.domain.trade
-
- CustomerCredit() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerCredit
-
- CustomerCredit(int, String, BigDecimal) - Constructor for class org.springframework.batch.sample.domain.trade.CustomerCredit
-
- CustomerCreditDao - Interface in org.springframework.batch.sample.domain.trade
-
Interface for writing customer's credit information to output.
- CustomerCreditFieldSetMapper - Class in org.springframework.batch.sample.domain.trade.internal
-
- CustomerCreditFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
-
- CustomerCreditIncreaseProcessor - Class in org.springframework.batch.sample.domain.trade.internal
-
Increases customer's credit by a fixed amount.
- CustomerCreditIncreaseProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
-
- CustomerCreditItemWriter - Class in org.springframework.batch.sample.domain.trade.internal
-
Delegates actual writing to a custom DAO.
- CustomerCreditItemWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
-
- CustomerCreditRepository - Interface in org.springframework.batch.sample.data
-
- CustomerCreditRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
-
- CustomerCreditRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
-
- CustomerCreditUpdatePreparedStatementSetter - Class in org.springframework.batch.sample.domain.trade.internal
-
- CustomerCreditUpdatePreparedStatementSetter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
-
- CustomerCreditUpdateWriter - Class in org.springframework.batch.sample.domain.trade.internal
-
- CustomerCreditUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
-
- CustomerDao - Interface in org.springframework.batch.sample.domain.trade
-
- CustomerDebit - Class in org.springframework.batch.sample.domain.trade
-
- CustomerDebit() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerDebit
-
- CustomerDebitDao - Interface in org.springframework.batch.sample.domain.trade
-
- CustomerDebitRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
-
- CustomerDebitRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
-
- CustomerFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
-
- CustomerFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
-
- CustomerFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
-
- CustomerFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
-
- CustomerOperation - Enum in org.springframework.batch.sample.domain.trade
-
Enum representing on of 3 possible actions on a customer update:
Add, update, or delete
- CustomerUpdate - Class in org.springframework.batch.sample.domain.trade
-
Immutable Value Object representing an update to the customer as stored in the database.
- CustomerUpdate(CustomerOperation, String, BigDecimal) - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdate
-
- CustomerUpdateFieldSetMapper - Class in org.springframework.batch.sample.domain.trade
-
- CustomerUpdateFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
-
- CustomerUpdateProcessor - Class in org.springframework.batch.sample.domain.trade
-
- CustomerUpdateProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
-
- CustomerUpdateWriter - Class in org.springframework.batch.sample.domain.trade
-
- CustomerUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
-
- CustomerUpdateWriter - Class in org.springframework.batch.sample.domain.trade.internal
-
Transforms Trade to a CustomerDebit and asks DAO delegate to write the
result.
- CustomerUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
-
- DatabaseType - Enum in org.springframework.batch.support
-
Enum representing a database type, such as DB2 or oracle.
- DataFieldMaxValueIncrementerFactory - Interface in org.springframework.batch.item.database.support
-
Factory for creating DataFieldMaxValueIncrementer
implementations
based upon a provided string.
- dataSource - Variable in class org.springframework.batch.core.jsr.JsrJobParametersConverter
-
- dataSource() - Method in class org.springframework.batch.sample.config.DataSourceConfiguration
-
- DataSourceConfiguration - Class in org.springframework.batch.sample.config
-
- DataSourceConfiguration() - Constructor for class org.springframework.batch.sample.config.DataSourceConfiguration
-
- DataSourceInitializer - Class in org.springframework.batch.test
-
Wrapper for a DataSource
that can run scripts on start up and shut
down.
- DataSourceInitializer() - Constructor for class org.springframework.batch.test.DataSourceInitializer
-
- DATE_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
- Db2PagingQueryProvider - Class in org.springframework.batch.item.database.support
-
- Db2PagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.Db2PagingQueryProvider
-
- decide(JobExecution, StepExecution) - Method in interface org.springframework.batch.core.job.flow.JobExecutionDecider
-
Strategy for branching an execution based on the state of an ongoing
JobExecution
.
- decide(JobExecution, StepExecution) - Method in class org.springframework.batch.sample.loop.LimitDecider
-
- DECISION_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- DecisionParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <decision/> elements inside a job.
- DecisionParser() - Constructor for class org.springframework.batch.core.configuration.xml.DecisionParser
-
- DecisionState - Class in org.springframework.batch.core.job.flow.support.state
-
State that requires a decider to make the status decision.
- DecisionState(JobExecutionDecider, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.DecisionState
-
- DecisionStep - Class in org.springframework.batch.core.jsr.step
-
Implements a
Step
to follow the rules for a decision state
as defined by JSR-352.
- DecisionStep(Decider) - Constructor for class org.springframework.batch.core.jsr.step.DecisionStep
-
- DecisionStepFactoryBean - Class in org.springframework.batch.core.jsr.configuration.xml
-
- DecisionStepFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
-
- DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
-
- DEFAULT_CHUNK_SIZE - Static variable in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
-
- DEFAULT_EXIT_MESSAGE_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- DEFAULT_JOB_EXECUTION_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default id for a job execution (123L)
- DEFAULT_JOB_INSTANCE_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default id for a job instance (12L)
- DEFAULT_JOB_NAME - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default name for a job ("job")
- DEFAULT_MAX_SKIPS_ON_READ - Static variable in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
-
Hard limit for number of read skips in the same chunk.
- DEFAULT_QUOTE_CHARACTER - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Convenient constant for the common case of a " character used to escape
delimiters or line endings.
- DEFAULT_STEP_EXECUTION_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default id for a step execution (1234L)
- DEFAULT_STEP_NAME - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default name for a step ("step")
- DEFAULT_SUFFIX - Static variable in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
-
Default value for record terminator suffix.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
Default value for the table prefix property.
- DEFAULT_THROTTLE_LIMIT - Static variable in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
-
Default limit for maximum number of concurrent unfinished results allowed
by the template.
- DEFAULT_TIMEOUT - Static variable in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
-
Default timeout value in milliseconds (the value equivalent to 30 seconds).
- DefaultBatchConfigurer - Class in org.springframework.batch.core.configuration.annotation
-
- DefaultBatchConfigurer() - Constructor for class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- DefaultBatchConfigurer(DataSource) - Constructor for class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- DefaultBufferedReaderFactory - Class in org.springframework.batch.item.file
-
- DefaultBufferedReaderFactory() - Constructor for class org.springframework.batch.item.file.DefaultBufferedReaderFactory
-
- DefaultDataFieldMaxValueIncrementerFactory - Class in org.springframework.batch.item.database.support
-
- DefaultDataFieldMaxValueIncrementerFactory(DataSource) - Constructor for class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
-
- DefaultExceptionHandler - Class in org.springframework.batch.repeat.exception
-
Default implementation of
ExceptionHandler
- just re-throws the exception it encounters.
- DefaultExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.DefaultExceptionHandler
-
- DefaultExecutionContextSerializer - Class in org.springframework.batch.core.repository.dao
-
An implementation of the
ExecutionContextSerializer
using the default
serialization implementations from Spring (
DefaultSerializer
and
DefaultDeserializer
).
- DefaultExecutionContextSerializer() - Constructor for class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
-
- DefaultFieldSet - Class in org.springframework.batch.item.file.transform
-
Default implementation of
FieldSet
using Java using Java primitive
and standard types and utilities.
- DefaultFieldSet(String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
-
Create a FieldSet with anonymous tokens.
- DefaultFieldSet(String[], String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
-
Create a FieldSet with named tokens.
- DefaultFieldSetFactory - Class in org.springframework.batch.item.file.transform
-
- DefaultFieldSetFactory() - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
- DefaultFragmentEventReader - Class in org.springframework.batch.item.xml.stax
-
- 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
-
- DefaultJobKeyGenerator() - Constructor for class org.springframework.batch.core.DefaultJobKeyGenerator
-
- DefaultJobLoader - Class in org.springframework.batch.core.configuration.support
-
- DefaultJobLoader() - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Default constructor useful for declarative configuration.
- DefaultJobLoader(JobRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Creates a job loader with the job registry provided.
- DefaultJobLoader(JobRegistry, StepRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Creates a job loader with the job and step registries provided.
- DefaultJobLoader - Class in org.springframework.batch.sample.launch
-
- DefaultJobLoader() - Constructor for class org.springframework.batch.sample.launch.DefaultJobLoader
-
- DefaultJobParametersConverter - Class in org.springframework.batch.core.converter
-
Converter for
JobParameters
instances using a simple naming
convention for property keys.
- DefaultJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
- DefaultJobParametersExtractor - Class in org.springframework.batch.core.step.job
-
Simple implementation of
JobParametersExtractor
which pulls
parameters with named keys out of the step execution context and the job
parameters of the surrounding job.
- DefaultJobParametersExtractor() - Constructor for class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
-
- DefaultJobParametersValidator - Class in org.springframework.batch.core.job
-
- DefaultJobParametersValidator() - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Convenient default constructor for unconstrained validation.
- DefaultJobParametersValidator(String[], String[]) - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Create a new validator with the required and optional job parameter keys
provided.
- DefaultLineMapper<T> - Class in org.springframework.batch.item.file.mapping
-
Two-phase
LineMapper
implementation consisting of tokenization of the line into
FieldSet
followed by
mapping to item.
- DefaultLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.DefaultLineMapper
-
- DefaultMailErrorHandler - Class in org.springframework.batch.item.mail
-
- DefaultMailErrorHandler() - Constructor for class org.springframework.batch.item.mail.DefaultMailErrorHandler
-
- DefaultPropertyEditorRegistrar - Class in org.springframework.batch.support
-
A re-usable PropertyEditorRegistrar
that can be used wherever one
needs to register custom PropertyEditor
instances with a
PropertyEditorRegistry
(like a bean wrapper, or a type converter).
- DefaultPropertyEditorRegistrar() - Constructor for class org.springframework.batch.support.DefaultPropertyEditorRegistrar
-
- DefaultRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
-
A
RecordSeparatorPolicy
that treats all lines as record endings, as
long as they do not have unterminated quotes, and do not end in a
continuation marker.
- DefaultRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
-
Default constructor.
- DefaultRecordSeparatorPolicy(String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
-
Convenient constructor with quote character as parameter.
- DefaultRecordSeparatorPolicy(String, String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
-
Convenient constructor with quote character and continuation marker as
parameters.
- DefaultResultCompletionPolicy - Class in org.springframework.batch.repeat.policy
-
Very simple
CompletionPolicy
that bases its decision on the result of
a batch operation.
- DefaultResultCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
-
- DefaultStateTransitionComparator - Class in org.springframework.batch.core.job.flow.support
-
Sorts by decreasing specificity of pattern, based on just counting
wildcards (with * taking precedence over ?).
- DefaultStateTransitionComparator() - Constructor for class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
-
- DefaultStepExecutionAggregator - Class in org.springframework.batch.core.partition.support
-
Convenience class for aggregating a set of
StepExecution
instances
into a single result.
- DefaultStepExecutionAggregator() - Constructor for class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
-
- DelegateStep - Class in org.springframework.batch.integration.step
-
Provides a wrapper for an existing
Step
, delegating execution to it,
but serving all other operations locally.
- DelegateStep() - Constructor for class org.springframework.batch.integration.step.DelegateStep
-
- delete - Variable in class org.springframework.batch.item.KeyValueItemWriter
-
- DelimitedLineAggregator<T> - Class in org.springframework.batch.item.file.transform
-
A
LineAggregator
implementation that converts an object into a
delimited list of strings.
- DelimitedLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineAggregator
-
- DelimitedLineTokenizer - Class in org.springframework.batch.item.file.transform
-
A
LineTokenizer
implementation that splits the input String on a
configurable delimiter.
- DelimitedLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
- DelimitedLineTokenizer(String) - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
- DELIMITER_COMMA - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Convenient constant for the common case of a comma delimiter.
- DELIMITER_TAB - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Convenient constant for the common case of a tab delimiter.
- DerbyPagingQueryProvider - Class in org.springframework.batch.item.database.support
-
- DerbyPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
-
- deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
-
Deserializes an execution context from the provided InputStream
.
- deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
-
- deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
-
Deserializes the supplied input stream into a new execution context.
- destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Unregister all the
Job
instances that were registered by this
post processor.
- destroy() - Method in class org.springframework.batch.sample.common.StagingItemReader
-
- destroy() - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
-
- destroy() - Method in class org.springframework.batch.test.DataSourceInitializer
-
- detectStreamInReader() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- DirectPoller<S> - Class in org.springframework.batch.poller
-
A
Poller
that uses the callers thread to poll for a result as soon as
it is asked for.
- DirectPoller(long) - Constructor for class org.springframework.batch.poller.DirectPoller
-
- DISCOUNT_AMOUNT_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
-
- DISCOUNT_PERC_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
-
- doAfterWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Call the listener's after write method.
- doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
-
- doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
-
Aggregate provided fields into single String.
- doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
-
- doAggregation(Collection<FlowExecution>, FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
-
- doAggregation(Collection<FlowExecution>, FlowExecutor) - Method in class org.springframework.batch.core.jsr.job.flow.support.state.JsrSplitState
-
Resets the
JobExecution
's exit status before aggregating the results of the flows within
the split.
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
-
- doCheckpoint() - Method in class org.springframework.batch.jsr.item.CheckpointSupport
-
Used to provide a Serializable
representing the current state of the
batch artifact.
- doCheckpoint() - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
-
- doCheckpoint() - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
-
- doCleanupAfterCompletion(Object) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
-
- doClose() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
-
- doClose() - Method in class org.springframework.batch.item.data.RepositoryItemReader
-
- doClose() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Close the cursor and database connection.
- doClose() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
- doClose() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
-
Close the cursor and hibernate session.
- doClose() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
-
- doClose() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
-
- doClose() - Method in class org.springframework.batch.item.file.FlatFileItemReader
-
- doClose() - Method in class org.springframework.batch.item.ldif.LdifReader
-
- doClose() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
-
- doClose() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
- doClose() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
-
- doClose() - Method in class org.springframework.batch.jsr.item.CheckpointSupport
-
Used to close the underlying batch artifact
- doClose() - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
-
- doClose() - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
-
- doCommit(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
-
- doExecute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
-
Extension point for subclasses allowing them to concentrate on processing
logic and ignore listeners and repository calls.
- doExecute(JobExecution) - Method in class org.springframework.batch.core.job.flow.FlowJob
-
- doExecute(StepExecution) - Method in class org.springframework.batch.core.job.flow.FlowStep
-
Delegate to the flow provided for the execution of the step.
- doExecute(JobExecution) - Method in class org.springframework.batch.core.job.SimpleJob
-
Handler of steps sequentially as provided, checking each one for success
before moving to the next.
- doExecute(JobExecution) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
-
- doExecute(StepExecution) - Method in class org.springframework.batch.core.jsr.step.DecisionStep
-
- doExecute(StepExecution) - Method in class org.springframework.batch.core.jsr.step.PartitionStep
-
- doExecute(StepExecution) - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
- doExecute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
-
Extension point for subclasses to execute business logic.
- doExecute(StepExecution) - Method in class org.springframework.batch.core.step.job.JobStep
-
Execute the job provided by delegating to the
JobLauncher
to
prevent duplicate executions.
- doExecute(StepExecution) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Process the step and update its context so that progress can be monitored
by the caller.
- doExecute(StepExecution) - Method in class org.springframework.batch.integration.step.DelegateStep
-
- doExecutionRegistration(StepExecution) - Method in class org.springframework.batch.core.jsr.step.BatchletStep
-
- doExecutionRegistration(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
-
- doExecutionRelease() - Method in class org.springframework.batch.core.step.AbstractStep
-
- doGetTransaction() - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
-
- doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
Executes the specified
StepExecution
instances and returns an updated
view of them.
- doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
- doInChunkContext(RepeatContext, ChunkContext) - Method in class org.springframework.batch.core.scope.context.StepContextRepeatCallback
-
Do the work required for this chunk of the step.
- doInIteration(RepeatContext) - Method in class org.springframework.batch.core.scope.context.StepContextRepeatCallback
-
- doInIteration(RepeatContext) - Method in class org.springframework.batch.repeat.callback.NestedRepeatCallback
-
Simply calls template.execute(callback).
- doInIteration(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatCallback
-
Implementations return true if they can continue processing - e.g.
- doInJobScope(JobExecution, Callable<T>) - Static method in class org.springframework.batch.test.JobScopeTestUtils
-
- doInStepScope(StepExecution, Callable<T>) - Static method in class org.springframework.batch.test.StepScopeTestUtils
-
- doJumpToPage(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
- doJumpToPage(int) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
-
- doJumpToPage(int) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
-
Deprecated.
- doJumpToPage(int) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
-
- doJumpToPage(int) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
-
- DONE - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
-
- doOnWriteError(Exception, List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- doOpen() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
-
- doOpen() - Method in class org.springframework.batch.item.data.RepositoryItemReader
-
- doOpen() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Execute the statement to open the cursor.
- doOpen() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
- doOpen() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
-
Open hibernate session and create a forward-only cursor for the query.
- doOpen() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
-
- doOpen() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
-
- doOpen() - Method in class org.springframework.batch.item.file.FlatFileItemReader
-
- doOpen() - Method in class org.springframework.batch.item.ldif.LdifReader
-
- doOpen() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
-
- doOpen() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
Open resources necessary to start reading input.
- doOpen() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
-
- doOpen(Serializable) - Method in class org.springframework.batch.jsr.item.CheckpointSupport
-
Used to open a batch artifact with previously saved checkpoint information.
- doOpen(Serializable) - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
-
- doOpen(Serializable) - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
-
- doPageRead() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
-
Method this
ItemStreamReader
delegates to
for the actual work of reading a page.
- doPageRead() - Method in class org.springframework.batch.item.data.MongoItemReader
-
- doPageRead() - Method in class org.springframework.batch.item.data.Neo4j4ItemReader
-
- doPageRead() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
- doPageRead() - Method in class org.springframework.batch.item.data.RepositoryItemReader
-
Performs the actual reading of a page via the repository.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.InlineFlowParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobParser
-
Create a bean definition for a
FlowJob
.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelFlowParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
-
- doPersist(StepContribution, Chunk<O>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
-
Implements writing and all related listener calls
- doProcess(I) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- doProvide(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
-
Implements reading as well as any related listener calls required.
- doRead() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
-
Surrounds the read call with listener callbacks.
- doRead() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
-
- doRead() - Method in class org.springframework.batch.item.data.RepositoryItemReader
-
- doRead() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
- doRead() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
- doRead() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
-
- doRead() - Method in class org.springframework.batch.item.file.FlatFileItemReader
-
- doRead() - Method in class org.springframework.batch.item.ldif.LdifReader
-
- doRead() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
-
- doRead() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
Read next item from input.
- doRead() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
-
Move to next fragment and map it to item.
- doReadPage() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
- doReadPage() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
-
- doReadPage() - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
-
Deprecated.
- doReadPage() - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
-
- doReadPage() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
-
- doRollback(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
-
- doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
-
- doStronglyTypedLogging(Object) - Method in class org.springframework.batch.sample.common.LogAdvice
-
- doTokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
-
- doTokenize(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Yields the tokens resulting from the splitting of the supplied
line
.
- doTokenize(String) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
-
Yields the tokens resulting from the splitting of the supplied
line
.
- doTokenize(String) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
-
- doTransform(I) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
-
Implements processing and all related listener calls.
- doUpdate(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
Extension point for subclasses.
- doWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Surrounds the actual write call with listener callbacks.
- doWrite(List<? extends T>) - Method in class org.springframework.batch.item.data.MongoItemWriter
-
Performs the actual write to the store via the template.
- doWrite(List<? extends T>) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
-
Performs the actual write using the template.
- doWrite(List<? extends T>) - Method in class org.springframework.batch.item.data.RepositoryItemWriter
-
Performs the actual write to the repository.
- doWrite(SessionFactory, List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
-
Do perform the actual write operation using Hibernate's API.
- doWrite(HibernateOperations, List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
-
- doWrite(EntityManager, List<? extends T>) - Method in class org.springframework.batch.item.database.JpaItemWriter
-
Do perform the actual write operation.
- DummyItemWriter - Class in org.springframework.batch.sample.support
-
- DummyItemWriter() - Constructor for class org.springframework.batch.sample.support.DummyItemWriter
-
- DuplicateJobException - Exception in org.springframework.batch.core.configuration
-
Checked exception that indicates a name clash when registering
Job
instances.
- DuplicateJobException(String) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
-
Create an exception with the given message.
- DuplicateJobException(String, Throwable) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
-
- DynamicMethodInvocationException - Exception in org.springframework.batch.item.adapter
-
Indicates an error has been encountered while trying to dynamically invoke a
method e.g.
- DynamicMethodInvocationException(Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
-
- DynamicMethodInvocationException(String, Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
-
- fail() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Signal the end of the flow with an error condition.
- FAIL_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- FAILED - Static variable in class org.springframework.batch.core.ExitStatus
-
Convenient constant value representing finished processing with an error.
- FAILED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
Special well-known status value.
- FatalStepExecutionException - Exception in org.springframework.batch.core.step
-
- FatalStepExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.FatalStepExecutionException
-
- faultTolerant() - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
-
- faultTolerant() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- FaultTolerantChunkProcessor<I,O> - Class in org.springframework.batch.core.step.item
-
FaultTolerant implementation of the
ChunkProcessor
interface, that
allows for skipping or retry of items that cause exceptions during writing.
- FaultTolerantChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, BatchRetryTemplate) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- FaultTolerantChunkProvider<I> - Class in org.springframework.batch.core.step.item
-
FaultTolerant implementation of the
ChunkProcessor
interface, that
allows for skipping or retry of items that cause exceptions during reading or
processing.
- FaultTolerantChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
-
- FaultTolerantStepBuilder<I,O> - Class in org.springframework.batch.core.step.builder
-
A step builder for fully fault tolerant chunk-oriented item processing steps.
- FaultTolerantStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Create a new builder initialized with any properties in the parent.
- FaultTolerantStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Create a new builder initialized with any properties in the parent.
- FaultTolerantStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
-
Factory bean for step that provides options for configuring skip behavior.
- FaultTolerantStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
-
- FieldExtractor<T> - Interface in org.springframework.batch.item.file.transform
-
This class will convert an object to an array of its parts.
- FieldSet - Interface in org.springframework.batch.item.file.transform
-
Interface used by flat file input sources to encapsulate concerns of
converting an array of Strings to Java native types.
- FieldSetFactory - Interface in org.springframework.batch.item.file.transform
-
Factory interface for creating
FieldSet
instances.
- FieldSetMapper<T> - Interface in org.springframework.batch.item.file.mapping
-
Interface that is used to map data obtained from a
FieldSet
into an
object.
- FileUtils - Class in org.springframework.batch.item.util
-
Utility methods for files used in batch processing.
- findAllReachableElements(String, Map<String, Set<String>>, Set<String>) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Find all of the elements reachable from the startElement.
- findAutowiredAnnotation(AccessibleObject) - Method in class org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
-
- findAutowiringMetadata(Class<?>) - Method in class org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
-
- findBatchStatus(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- findByCreditGreaterThan(BigDecimal, Pageable) - Method in interface org.springframework.batch.sample.data.CustomerCreditRepository
-
- findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- findJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Return all
JobExecution
for given
JobInstance
, sorted
backwards by creation order (so the first element is the most recent).
- findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- findJobInstancesByJobName(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Fetch
JobInstance
values in descending order of creation (and
there for usually of first execution) with a 'like'/wildcard criteria.
- findJobInstancesByJobName(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- findJobInstancesByName(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- findJobInstancesByName(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the last job instances with the provided name, sorted backwards by
primary key, using a 'like' criteria
- findJobInstancesByName(String, int, int) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- findMatchingMethod() - Method in class org.springframework.batch.item.adapter.HippyMethodInvoker
-
- findMethod(Object) - Method in class org.springframework.batch.support.AnnotationMethodResolver
-
Find a single Method on the Class of the given candidate object
that contains the annotation type for which this resolver is searching.
- findMethod(Class<?>) - Method in class org.springframework.batch.support.AnnotationMethodResolver
-
Find a single Method on the given Class that contains the
annotation type for which this resolver is searching.
- findMethod(Object) - Method in interface org.springframework.batch.support.MethodResolver
-
Find a single Method on the provided Object that matches this resolver's
criteria.
- findMethod(Class<?>) - Method in interface org.springframework.batch.support.MethodResolver
-
Find a single Method on the given Class that matches this
resolver's criteria.
- findMethod(Class, Class<? extends Annotation>) - Static method in class org.springframework.batch.support.ReflectionUtils
-
Returns a Set
of Method
instances that
are annotated with the annotation provided.
- findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve running job executions.
- findRunningJobExecutions(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
- findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- FIRST_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
-
- FIXED_AMOUNT - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
-
- FIXED_AMOUNT - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
-
- FixedLengthTokenizer - Class in org.springframework.batch.item.file.transform
-
Tokenizer used to process data obtained from files with fixed-length format.
- FixedLengthTokenizer() - Constructor for class org.springframework.batch.item.file.transform.FixedLengthTokenizer
-
- FlatFileCustomerCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
-
Writes customer's credit information in a file.
- FlatFileCustomerCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
-
- FlatFileFooterCallback - Interface in org.springframework.batch.item.file
-
Callback interface for writing a footer to a file.
- FlatFileFormatException - Exception in org.springframework.batch.item.file.transform
-
Exception indicating that some type of error has occurred while
attempting to parse a line of input into tokens.
- FlatFileFormatException(String, String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
- FlatFileFormatException(String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
- FlatFileFormatException(String, Throwable) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
- FlatFileHeaderCallback - Interface in org.springframework.batch.item.file
-
Callback interface for writing to a header to a file.
- FlatFileItemReader<T> - Class in org.springframework.batch.item.file
-
- FlatFileItemReader() - Constructor for class org.springframework.batch.item.file.FlatFileItemReader
-
- FlatFileItemWriter<T> - Class in org.springframework.batch.item.file
-
This class is an item writer that writes data to a file or stream.
- FlatFileItemWriter() - Constructor for class org.springframework.batch.item.file.FlatFileItemWriter
-
- FlatFileParseException - Exception in org.springframework.batch.item.file
-
Exception thrown when errors are encountered
parsing flat files.
- FlatFileParseException(String, String) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
-
- FlatFileParseException(String, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
-
- FlatFileParseException(String, Throwable, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
-
- flow() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
- flow(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Provide a single flow to execute as the job.
- flow(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
-
Create a new job builder that will execute a step or sequence of steps.
- Flow - Interface in org.springframework.batch.core.job.flow
-
- flow - Variable in class org.springframework.batch.core.job.flow.FlowJob
-
- flow(Flow) - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
-
Provide a flow to execute during the step.
- flow(Flow) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Create a new step builder that will execute a flow.
- FLOW_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- FlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for a flow of steps that can be executed as a job or as part of a job.
- FlowBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder
-
- FlowBuilder.SplitBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for building a split state.
- FlowBuilder.TransitionBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for transitions within a flow.
- FlowBuilder.UnterminatedFlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for continuing a flow from a decision state.
- FlowBuilderException - Exception in org.springframework.batch.core.job.builder
-
- FlowBuilderException(String, Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
-
- FlowBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
-
- FlowBuilderException(String) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
-
- FlowElementParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <flow/> elements inside a job.
- FlowElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.FlowElementParser
-
- FlowExecution - Class in org.springframework.batch.core.job.flow
-
- FlowExecution(String, FlowExecutionStatus) - Constructor for class org.springframework.batch.core.job.flow.FlowExecution
-
- FlowExecutionAggregator - Interface in org.springframework.batch.core.job.flow.support.state
-
Strategy interface for aggregating
FlowExecution
instances into a
single exit status.
- FlowExecutionException - Exception in org.springframework.batch.core.job.flow
-
- FlowExecutionException(String) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
-
- FlowExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
-
- FlowExecutionStatus - Class in org.springframework.batch.core.job.flow
-
- FlowExecutionStatus(String) - Constructor for class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
- FlowExecutor - Interface in org.springframework.batch.core.job.flow
-
Context and execution strategy for
FlowJob
to allow it to delegate
its execution step by step.
- FlowHolder - Interface in org.springframework.batch.core.job.flow
-
Convenient interface for components that contain nested flows.
- FlowJob - Class in org.springframework.batch.core.job.flow
-
Implementation of the
Job
interface that allows for complex flows of
steps, rather than requiring sequential execution.
- FlowJob() - Constructor for class org.springframework.batch.core.job.flow.FlowJob
-
Create a
FlowJob
with null name and no flow (invalid state).
- FlowJob(String) - Constructor for class org.springframework.batch.core.job.flow.FlowJob
-
Create a
FlowJob
with provided name and no flow (invalid state).
- FlowJobBuilder - Class in org.springframework.batch.core.job.builder
-
A job builder for
FlowJob
instances.
- FlowJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Create a new builder initialized with any properties in the parent.
- FlowParser - Class in org.springframework.batch.core.jsr.configuration.xml
-
Parses flows as defined in JSR-352.
- FlowParser(String, String) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.FlowParser
-
- FlowState - Class in org.springframework.batch.core.job.flow.support.state
-
State that delegates to a Flow
- FlowState(Flow, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.FlowState
-
- FlowStep - Class in org.springframework.batch.core.job.flow
-
A
Step
implementation that delegates to a
Flow
.
- FlowStep() - Constructor for class org.springframework.batch.core.job.flow.FlowStep
-
Default constructor convenient for configuration purposes.
- FlowStep(Flow) - Constructor for class org.springframework.batch.core.job.flow.FlowStep
-
Constructor for a
FlowStep
that sets the flow and of the step
explicitly.
- FlowStepBuilder - Class in org.springframework.batch.core.step.builder
-
- FlowStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FlowStepBuilder
-
Create a new builder initialized with any properties in the parent.
- flush() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
-
- FlushFailedException - Exception in org.springframework.batch.support.transaction
-
Unchecked exception indicating that an error has occurred while trying to flush a buffer.
- FlushFailedException(String, Throwable) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
-
- FlushFailedException(String) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
-
- FootballExceptionHandler - Class in org.springframework.batch.sample.domain.football.internal
-
- FootballExceptionHandler - Class in org.springframework.batch.sample.domain.football.internal
-
- FootballExceptionHandler() - Constructor for class org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
-
- FooterFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
-
- FooterFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
-
- ForceRollbackForWriteSkipException - Exception in org.springframework.batch.core.step.item
-
Fatal exception to be thrown when a rollback must be forced, typically after
catching an exception that otherwise would not cause a rollback.
- ForceRollbackForWriteSkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.item.ForceRollbackForWriteSkipException
-
- FormatterLineAggregator<T> - Class in org.springframework.batch.item.file.transform
-
A
LineAggregator
implementation which produces a String by
aggregating the provided item via the
Formatter
syntax.
- FormatterLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.FormatterLineAggregator
-
- FragmentEventReader - Interface in org.springframework.batch.item.xml.stax
-
Interface for event readers which support treating XML fragments as standalone XML documents
by wrapping the fragments with StartDocument and EndDocument events.
- from(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Go back to a previously registered step and start a new path.
- from(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Start again from a decision that was already registered.
- from(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Start again from a subflow that was already registered.
- fromCode(char) - Static method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
-
- fromMetaData(DataSource) - Static method in enum org.springframework.batch.support.DatabaseType
-
Convenience method that pulls a database product name from the DataSource's metadata.
- fromProductName(String) - Static method in enum org.springframework.batch.support.DatabaseType
-
Static method to obtain a DatabaseType from the provided product name.
- fromPropertyName(String) - Static method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
-
Return the relevant meta data for the provided property name.
- fromPropertyName(String) - Static method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
-
Return the relevant meta data for the provided property name.
- fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
Return the relevant meta data for the provided property name.
- fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
Return the relevant meta data for the provided property name.
- Game - Class in org.springframework.batch.core.test.football
-
- Game() - Constructor for class org.springframework.batch.core.test.football.Game
-
- Game - Class in org.springframework.batch.sample.domain.football
-
- Game() - Constructor for class org.springframework.batch.sample.domain.football.Game
-
- GameFieldSetMapper - Class in org.springframework.batch.sample.domain.football.internal
-
- GameFieldSetMapper - Class in org.springframework.batch.sample.domain.football.internal
-
- GameFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.GameFieldSetMapper
-
- GemfireItemWriter<K,V> - Class in org.springframework.batch.item.data
-
- GemfireItemWriter() - Constructor for class org.springframework.batch.item.data.GemfireItemWriter
-
- generateFirstPageQuery(int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Generate the query that will provide the first page, limited by the page size.
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
Method generating the query string to be used for retrieving the first
page.
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
-
- generateGroupedTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a TOP clause
- generateJumpToItemQuery(int, int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Generate the query that will provide the jump to item query.
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
Method generating the query string to be used for jumping to a specific
item position.
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
-
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
-
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
-
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
-
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
-
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
-
- generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- generateKey(JobParameters) - Method in class org.springframework.batch.core.DefaultJobKeyGenerator
-
Generates the job key to be used based on the
JobParameters
instance
provided.
- generateKey(T) - Method in interface org.springframework.batch.core.JobKeyGenerator
-
Method to generate the unique key used to identify a job instance.
- generateLimitCypherQuery() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
-
- generateLimitGroupedSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a LIMIT clause
- generateLimitJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a LIMIT clause
- generateLimitSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a LIMIT clause
- generateRemainingPagesQuery(int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Generate the query that will provide the first page, limited by the page size.
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
Method generating the query string to be used for retrieving the pages
following the first page.
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
-
- generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a ROW_NUM condition
- generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a ROW_NUM condition
- generateRowNumSqlQueryWithNesting(AbstractSqlPagingQueryProvider, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
- generateRowNumSqlQueryWithNesting(AbstractSqlPagingQueryProvider, String, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
- generateTopJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a TOP clause
- generateTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a TOP clause
- GeneratingTradeItemReader - Class in org.springframework.batch.sample.domain.trade.internal
-
Generates configurable number of
Trade
items.
- GeneratingTradeItemReader() - Constructor for class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
-
- GeneratingTradeResettingListener - Class in org.springframework.batch.sample.loop
-
This listener resets the count of its GeneratingTradeItemReader after the
step.
- GeneratingTradeResettingListener() - Constructor for class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
-
- GenericApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
- GenericApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
-
Create an application context factory for the resource specified.
- get(String) - Method in class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
-
Creates a job builder and initializes its job repository.
- get(String) - Method in class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
-
Creates a step builder and initializes its job repository and transaction manager.
- get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.JobScope
-
- get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.StepScope
-
- get(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Getter for the value represented by the provided key.
- getActualCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
-
- getActualLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
-
- getAddress() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
-
- getAddress() - Method in class org.springframework.batch.sample.domain.person.Person
-
- getAddressee() - Method in class org.springframework.batch.sample.domain.order.Address
-
- getAddrLine1() - Method in class org.springframework.batch.sample.domain.order.Address
-
- getAddrLine2() - Method in class org.springframework.batch.sample.domain.order.Address
-
- getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Extension point for subclasses that want to adjust the outputs based on
additional saved data in the inputs.
- getAge() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
-
- getAge() - Method in class org.springframework.batch.sample.domain.person.Person
-
- getAggregator() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
-
Return all failure causing exceptions for this JobExecution, including
step executions.
- getAllowStartIfComplete() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getAnnotation() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
-
- getAnnotation() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
-
- getAnnotation() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getAnnotation() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getApplicationContext() - Method in class org.springframework.batch.test.AbstractJobTests
-
Deprecated.
- getArguments() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
-
Return arguments.
- getArtifactProperties(String) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
-
Obtains the batch Properties
for the provided artifact name.
- getAsText() - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
-
- getAttempts() - Method in class org.springframework.batch.core.test.football.Game
-
- getAttempts() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getAttempts() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getAttempts() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
-
- getAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
-
- getBatchStatus() - Method in enum org.springframework.batch.core.BatchStatus
-
Converts the current status to the JSR-352 equivalent
- getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrJobContext
-
- getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getBatchStatusFromEndTransitionName(String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
-
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
-
- getBeanClass(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
-
- getBeanClassName(Element) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
-
- getBeanFactoryPostProcessorClasses() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Protected access to the list of bean factory post processor classes that should be copied over to the context
from the parent.
- getBilling() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getBillingAddress() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getBirthYear() - Method in class org.springframework.batch.core.test.football.Player
-
- getBirthYear() - Method in class org.springframework.batch.sample.domain.football.Player
-
- getBufferSize() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
-
Convenience method for clients to determine if there is any unflushed
data.
- getChildren() - Method in class org.springframework.batch.sample.domain.person.Person
-
- 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
-
- getCity() - Method in class org.springframework.batch.sample.domain.order.Address
-
- getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getCloseSuppressingConnectionProxy(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
Wrap the given Connection with a proxy that delegates every method call
to it but suppresses close calls.
- getCode() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
-
- getCode() - Method in enum org.springframework.batch.item.file.transform.Alignment
-
- getCode() - Method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
-
- getCommitCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of commits for this execution
- getCommitInterval() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getCompanyName() - Method in class org.springframework.batch.sample.domain.order.Customer
-
- getCompletes() - Method in class org.springframework.batch.core.test.football.Game
-
- getCompletes() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getCompletes() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getCompletes() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getCompletionPolicy() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getConfigurations() - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
-
- getConfigurations() - Method in interface org.springframework.batch.sample.launch.JobLoader
-
- getConfigurer(Collection<BatchConfigurer>) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
-
- getConnection() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
- getConnection(String, String) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
- getContext() - Static method in class org.springframework.batch.core.scope.context.JobSynchronizationManager
-
Getter for the current context if there is one, otherwise returns null.
- getContext() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
-
Getter for the current context if there is one, otherwise returns null.
- getContext() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
Getter for the current context if there is one, otherwise returns null.
- getContext() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
-
Getter for the current context.
- getConversationId() - Method in class org.springframework.batch.core.scope.JobScope
-
- getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
-
- getCount() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
-
- getCount(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
Extension point for subclasses.
- getCounter() - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
-
- getCounter() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
-
- getCounter() - Method in class org.springframework.batch.sample.support.RetrySampleItemWriter
-
- getCountry() - Method in class org.springframework.batch.sample.domain.order.Address
-
- getCreateTime() - Method in class org.springframework.batch.core.JobExecution
-
- getCreateTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getCredit() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
-
- getCredit() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
-
- getCurrent() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
- getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
- getCurrentResource() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
-
- getCustomer() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
-
- getCustomer() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getCustomer() - Method in class org.springframework.batch.sample.domain.trade.Trade
-
- getCustomerByName(String) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
-
- getCustomerByName(String) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
-
- getCustomerName() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
-
- getData() - Method in class org.springframework.batch.sample.domain.person.PersonService
-
- getDataSource() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Public getter for the data source.
- getDate(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Date represented by the provided key.
- getDate(String, Date) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Date represented by the provided key.
- getDate() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
-
- getDebit() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
-
- getDebutYear() - Method in class org.springframework.batch.core.test.football.Player
-
- getDebutYear() - Method in class org.springframework.batch.sample.domain.football.Player
-
- getDefaultExitStatusForFailure(Throwable, JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
-
- getDefaultExitStatusForFailure(Throwable, JobExecution) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
-
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getDescription() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
-
- getDiscountAmount() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getDiscountPerc() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getDouble(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Long represented by the provided key.
- getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Double represented by the provided key.
- getDouble(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the Double represented by the provided key.
- getDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the Double represented by the provided key with
default value to return if key is not represented.
- getEmail() - Method in class org.springframework.batch.sample.domain.mail.User
-
- getEncoding() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get used encoding.
- getEndTime() - Method in class org.springframework.batch.core.JobExecution
-
- getEndTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getEndTime() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getEndTime() - Method in class org.springframework.batch.core.StepExecution
-
Returns the time that this execution ended
- 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
-
- getErrors() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
-
Public getter for the startup errors encountered during parent context
creation.
- getErrors() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getErrors() - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
-
Public accessor for the errors property.
- getException() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
To support both JSR-352's requirement to return the most recent exception
and Spring Batch's support for
Throwable
, this implementation will
return the most recent exception in the underlying
StepExecution
's
failure exceptions list.
- getException() - Method in class org.springframework.batch.core.step.item.SkipWrapper
-
Public getter for the exception.
- getExceptionHandler() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to access the exception handler that was injected by user.
- getExceptionHandler() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- 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
-
- getExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
- getExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
- getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
- getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
-
- getExecutionContext() - Method in class org.springframework.batch.core.StepExecution
-
- getExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getExecutionContextKey(String) - Method in class org.springframework.batch.item.ItemStreamSupport
-
- getExecutionId() - Method in class org.springframework.batch.core.jsr.JsrJobContext
-
- getExecutionId() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getExecutions(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the
JobExecutions
associated with a particular
JobInstance
, in reverse order of creation (and therefore usually
of execution).
- getExecutions(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getExitCode() - Method in class org.springframework.batch.core.ExitStatus
-
Getter for the exit code (defaults to blank).
- getExitDescription() - Method in class org.springframework.batch.core.ExitStatus
-
Getter for the exit description (defaults to blank)
- getExitStatus() - Method in class org.springframework.batch.core.JobExecution
-
- getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrJobContext
-
- getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
-
- getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
-
- getExitStatus(int) - Method in interface org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
-
- getExitStatus() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the status.
- getExitStatus() - Method in class org.springframework.batch.core.StepExecution
-
- getExpectedCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
-
- getExpectedLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
-
- getFailedMessages() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
-
- getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
-
- getFailureExceptions() - Method in class org.springframework.batch.core.StepExecution
-
- getFatalExceptionAwareProxy(SkipPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Wrap a
SkipPolicy
and make it consistent with known fatal exceptions.
- getFaultTolerantStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getFaultTolerantStepBuilder(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
-
- getFieldCount() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
-
- getFieldCount() - Method in interface org.springframework.batch.item.file.transform.FieldSet
-
Return the number of fields in this 'FieldSet
'.
- getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
-
- getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Extension point for subclasses to calculate the filter count.
- getFilterCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the filter counter.
- getFilterCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items filtered out of this execution
- getFirstName() - Method in class org.springframework.batch.core.test.football.Player
-
- getFirstName() - Method in class org.springframework.batch.sample.domain.football.Player
-
- getFirstName() - Method in class org.springframework.batch.sample.domain.order.Customer
-
- getFirstName() - Method in class org.springframework.batch.sample.domain.person.Person
-
- getFlows() - Method in 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
-
- getFooter() - Static method in class org.springframework.batch.sample.domain.multiline.AggregateItem
-
- getForwardOnlyCursor(int, Map<String, Object>) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
-
Get a cursor over all of the results, with the forward-only flag set.
- getFromClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
- getGridSize() - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
Returns the number of step executions.
- getGridSize() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getGroupClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
The getter for the group by clause
- getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Determine a group name for the job to be registered.
- getHandlingPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getHeader() - Static method in class org.springframework.batch.sample.domain.multiline.AggregateItem
-
- getId() - Method in class org.springframework.batch.core.Entity
-
- getId() - Method in class org.springframework.batch.core.scope.context.JobContext
-
- getId() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getId() - Method in class org.springframework.batch.core.test.football.Game
-
- getId() - Method in class org.springframework.batch.core.test.football.Player
-
- getId() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getId() - Method in class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
-
- getId() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getId() - Method in class org.springframework.batch.sample.domain.football.Player
-
- getId() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getId() - Method in class org.springframework.batch.sample.domain.mail.User
-
- getId() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
-
- getId() - Method in class org.springframework.batch.sample.domain.trade.Trade
-
- getIncrementer(String, String) - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
-
Return the DataFieldMaxValueIncrementer
for the provided database type.
- getIncrementer(String, String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
-
- getInput() - Method in exception org.springframework.batch.item.file.FlatFileParseException
-
- getInput() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
-
- getInput() - Method in exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
- getInput() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
-
- getInputChannelAttributeName() - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
-
- getInstanceId() - Method in class org.springframework.batch.core.JobInstance
-
- getInstanceId() - Method in class org.springframework.batch.core.jsr.JsrJobContext
-
- getInt(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the Integer represented by the provided key.
- getInt(String, int) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the Integer represented by the provided key with
default value to return if key is not represented.
- getInterceptions() - Method in class org.springframework.batch.core.test.football.Game
-
- getInterceptions() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getInterceptions() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getInterceptions() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getIsin() - Method in class org.springframework.batch.sample.domain.trade.Trade
-
- getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
-
Public getter for the item.
- getItem() - Method in class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
-
- getItem() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
-
Accessor for the wrapped item.
- getItemId() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getItemListeners() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getItemProcessor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- getItemReader() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemReader
for subclasses to use.
- getItems() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getItems() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
-
- getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemWriter
for subclasses to use
- getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
-
Locates a
Job
at runtime.
- getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
-
- getJob() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
-
- getJob() - Method in class org.springframework.batch.test.AbstractJobTests
-
Deprecated.
- getJob() - Method in class org.springframework.batch.test.JobLauncherTestUtils
-
- getJobConfiguration(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
-
- getJobConfiguration(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
-
- getJobConfigurationName() - Method in class org.springframework.batch.core.JobExecution
-
- getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
- getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
- getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- getJobExecution(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
- getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- getJobExecution() - Method in class org.springframework.batch.core.scope.context.JobContext
-
- getJobExecution() - Method in class org.springframework.batch.core.StepExecution
-
Accessor for the execution context information of the enclosing job.
- getJobExecution(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
-
Discover a
JobExecution
as a field in the test case or create
one if none is available.
- getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.JobContext
-
- getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getJobExecutionId() - Method in class org.springframework.batch.core.StepExecution
-
Accessor for the job execution id.
- getJobExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
-
- getJobExecutionListeners() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve job executions by their job instance.
- getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJobExplorer() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
-
- getJobExplorer() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- getJobId() - Method in class org.springframework.batch.core.JobExecution
-
Convenience getter for for the id of the enclosing job.
- getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
-
- getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
-
- getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
- getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobInstance() - Method in class org.springframework.batch.core.JobExecution
-
- getJobInstance(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
The job table is queried for any jobs that match the
given identifier, adding them to a list via the RowMapper callback.
- getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Find the job instance that matches the given name and parameters.
- getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the job instance with the provided identifier.
- getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the JobInstance for the provided JobExecution.
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstanceCount(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Query the repository for the number of unique
JobInstance
s
associated with the supplied job name.
- getJobInstanceCount(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobInstanceCount(String) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJobInstanceCount(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstanceCount(String) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Query the repository for the number of unique
JobInstance
s
associated with the supplied job name.
- getJobInstanceCount(String) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Fetch
JobInstance
values in descending order of creation (and
therefore usually of first execution).
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the
JobInstances
for a given job name, in
reverse order of creation (and therefore usually of first execution).
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the last job instances with the provided name, sorted backwards by
primary key.
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobLauncher() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
-
- getJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- getJobLauncher() - Method in class org.springframework.batch.test.AbstractJobTests
-
Deprecated.
- getJobLauncher() - Method in class org.springframework.batch.test.JobLauncherTestUtils
-
- getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
-
- getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
Just return the name of instance passed in on initialization.
- getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
-
Just return the name of instance passed in on initialization.
- getJobName() - Method in class org.springframework.batch.core.JobInstance
-
- getJobName() - Method in class org.springframework.batch.core.jsr.JsrJobContext
-
- getJobName() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getJobName() - Method in class org.springframework.batch.core.scope.context.JobContext
-
Convenient accessor for current job name identifier.
- getJobName() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current job name identifier.
- getJobNames() - Method in interface org.springframework.batch.core.configuration.ListableJobLocator
-
Provides the currently registered job names.
- getJobNames() - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
-
Provides an unmodifiable view of the job names.
- getJobNames() - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Query the repository for all unique
JobInstance
names (sorted
alphabetically).
- getJobNames() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getJobNames() - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJobNames() - Method in interface org.springframework.batch.core.launch.JobOperator
-
- getJobNames() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getJobNames() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
- getJobNames() - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Retrieve the names of all job instances sorted alphabetically - i.e.
- getJobNames() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
-
- getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Check for suffix on keys and use those to decide how to convert the
value.
- getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
-
- getJobParameters() - Method in class org.springframework.batch.core.JobExecution
-
- getJobParameters() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
-
- getJobParameters() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getJobParameters(Properties) - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
-
- getJobParameters(Properties) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
- getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- getJobParameters() - Method in class org.springframework.batch.core.scope.context.JobContext
-
- getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getJobParameters(Job, StepExecution) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
-
- getJobParameters(Job, StepExecution) - Method in interface org.springframework.batch.core.step.job.JobParametersExtractor
-
Extract job parameters from the step execution, for example from the
execution context or other properties.
- getJobParameters() - Method in class org.springframework.batch.core.StepExecution
-
Convenience method to get the current job parameters.
- getJobParameters() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
-
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.AbstractJob
-
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobParametersIncrementer() - Method in interface org.springframework.batch.core.Job
-
If clients need to generate new parameters for the next execution in a
sequence they can use this incrementer.
- getJobParametersValidator() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
- getJobParametersValidator() - Method in class org.springframework.batch.core.job.AbstractJob
-
- getJobParametersValidator() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobParametersValidator() - Method in interface org.springframework.batch.core.Job
-
- getJobProperties() - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
-
Obtains the Job level properties.
- getJobProperties() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
-
- getJobRepository() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
-
- getJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
-
- getJobRepository() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
-
- getJobRepository() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getJobRepository() - Method in class org.springframework.batch.core.job.AbstractJob
-
Convenience method for subclasses to access the job repository.
- getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
-
- getJobRepository() - Method in class org.springframework.batch.core.job.SimpleStepHandler
-
- getJobRepository() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
-
- getJobRepository() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- getJobRepository() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- getJobRepository() - Method in class org.springframework.batch.test.AbstractJobTests
-
Deprecated.
- getJobRepository() - Method in class org.springframework.batch.test.JobLauncherTestUtils
-
- getJobRestartProperties(Properties, JobExecution) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getJsrRetryListeners() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- getKey(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
-
- getLabel() - Method in enum org.springframework.batch.item.file.transform.Alignment
-
- getLast_name() - Method in class org.springframework.batch.sample.domain.person.Person
-
Intentionally non-standard method name for testing purposes
- getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
- getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
- getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
-
- getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- getLastName() - Method in class org.springframework.batch.core.test.football.Player
-
- getLastName() - Method in class org.springframework.batch.sample.domain.football.Player
-
- getLastName() - Method in class org.springframework.batch.sample.domain.order.Customer
-
- getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- getLastUpdated() - Method in class org.springframework.batch.core.JobExecution
-
Get the date representing the last time this JobExecution was updated in
the JobRepository.
- getLastUpdated() - Method in class org.springframework.batch.core.StepExecution
-
- getLastUpdatedTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getLimit() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
-
- getLineItems() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
-
- getLineItems() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getLineNumber() - Method in exception org.springframework.batch.item.file.FlatFileParseException
-
- getLineNumber() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
-
- getListener() - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
-
- getListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
Convenience method to wrap any object and expose the appropriate
StepListener
interfaces.
- getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
- getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
-
- getListenerInterface() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
-
- getListenerInterface() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
-
- getListenerInterface() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getListenerInterface() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
- getLoginTimeout() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
- getLogWriter() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
- getLong(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Long represented by the provided key.
- getLong(String, long) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the Long represented by the provided key.
- getLong(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the Long represented by the provided key.
- getLong(String, long) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the Long represented by the provided key with default
value to return if key is not represented.
- getMapping() - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
-
- getMax() - Method in class org.springframework.batch.item.file.transform.Range
-
- getMessage() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
-
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
-
- getMetaDataValues() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getMethodInvokerByAnnotation(Class<? extends Annotation>, Object, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create a MethodInvoker from the delegate based on the annotationType.
- getMethodInvokerByAnnotation(Class<? extends Annotation>, Object) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create
MethodInvoker
for the method with the provided annotation
on the provided object.
- getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getMethodInvokerByName(Object, String, boolean, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
- getMethodInvokerForInterface(Class<?>, String, Object, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create a
MethodInvoker
using the provided interface, and method
name from that interface.
- getMethodInvokerForSingleArgument(Object) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create a
MethodInvoker
for the delegate from a single public
method.
- getMethodName() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
-
- getMethodName() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
-
- getMethodName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getMethodName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getMetric(StepExecution, Metric.MetricType) - Static method in class org.springframework.batch.test.JsrTestUtils
-
- getMetrics() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getMetrics() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getMiddleName() - Method in class org.springframework.batch.sample.domain.order.Customer
-
- getMin() - Method in class org.springframework.batch.item.file.transform.Range
-
- getMoo() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
-
- getMostRecentStepName() - Method in class org.springframework.batch.core.jsr.job.flow.support.JsrFlow
-
- getName() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
Concatenates the group name and the delegate job name (joining with a
".").
- getName() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getName() - Method in class org.springframework.batch.core.job.AbstractJob
-
- getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
-
- getName() - Method in interface org.springframework.batch.core.job.flow.Flow
-
- getName() - Method in class org.springframework.batch.core.job.flow.FlowExecution
-
- getName() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
- getName() - Method in interface org.springframework.batch.core.job.flow.State
-
The name of the state.
- getName() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Get the name for this flow.
- getName() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
-
- getName() - Method in interface org.springframework.batch.core.Job
-
- getName() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
-
- getName() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
-
- getName() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public getter for the name of the step.
- getName() - Method in interface org.springframework.batch.core.Step
-
- getName() - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
-
- getName() - Method in class org.springframework.batch.sample.domain.mail.User
-
- getName() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
-
- getName() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
-
- getName() - Method in class org.springframework.batch.sample.domain.person.Child
-
- getName() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
-
- getName() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
-
- getNames() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
-
- getNames() - Method in interface org.springframework.batch.item.file.transform.FieldSet
-
Accessor for the names of the fields.
- getNext() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Public getter for the next State name.
- getNext(JobParameters) - Method in interface org.springframework.batch.core.JobParametersIncrementer
-
Increment the provided parameters.
- getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
-
Increment the run.id parameter (starting with 1).
- getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
-
- getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
-
- getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
-
Get the next completed result, possibly executing several callbacks until
one finally finishes.
- getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
-
- getObject() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Create a
Step
from the configuration provided.
- getObject() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
-
Create a
Step
from the configuration provided.
- getObject() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- getObject() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Create a
Step
from the configuration provided.
- getObject() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
- getObject() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
-
- 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
-
- getObjectType() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
The type of object to be returned from FactoryBean.getObject()
.
- getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
- getObjectType() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
- 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
-
- getOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
-
- getOperation() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
-
- getOpponent() - Method in class org.springframework.batch.core.test.football.Game
-
- getOpponent() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getOrder() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- getOrder() - Method in class org.springframework.batch.core.jsr.configuration.support.ThreadLocalClassloaderBeanPostProcessor
-
Sets this BeanFactoryPostProcessor
to the lowest precedence so that
it is executed as late as possible in the chain of BeanFactoryPostProcessor
s
- getOrder() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
-
- getOrderDate() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
-
- getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- getOrderId() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getOverClause() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
-
- getOverClause() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- getOverSubstituteClauseEnd() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
-
- getOverSubstituteClauseEnd() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- getOverSubstituteClauseStart() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
-
- getOverSubstituteClauseStart() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
-
- getPage() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
The current page number.
- getPageSize() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
The page size configured for this reader.
- getParameterCount() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
The number of parameters that are declared in the query
- getParameterCount() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
- getParameters() - Method in class org.springframework.batch.core.JobParameters
-
Get a map of all parameters, including string, long, and date.
- getParameters(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getParameters(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
- getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getParameterValues() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
-
- getParamTypes() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
-
- getParamTypes() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
-
- getParamTypes() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getParamTypes() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getParamTypesString(Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create a String representation of the array of parameter types.
- getParent() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
-
- getParent() - Method in interface org.springframework.batch.repeat.RepeatContext
-
If batches are nested, then the inner batch will be created with the
outer one as a parent.
- getParentLogger() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
Added due to JDK 7 compatibility.
- getPartitioner() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getPartitionHandler() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getPartitionHandler() - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
- getPartitionHandler() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
-
- getPartitionPlan() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getPartitionProperties() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
-
- getPartitions() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
-
- getPartitionsOverride() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
-
- getPartitionStepNames() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
-
- getPassingTd() - Method in class org.springframework.batch.core.test.football.Game
-
- getPassingTd() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getPassingTd() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getPassingTd() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getPassingYards() - Method in class org.springframework.batch.core.test.football.Game
-
- getPassingYards() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getPassingYards() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getPassingYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getPattern() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
- getPaymentDesc() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
-
- getPaymentId() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
-
- getPerOunceRate() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
-
- getPersistentUserData() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getPersistentUserData() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getPerUnitOunces() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
-
- getPhase() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
- getPoo() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
-
- getPosition() - Method in class org.springframework.batch.core.test.football.Player
-
- getPosition() - Method in class org.springframework.batch.sample.domain.football.Player
-
- getPrice() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
-
- getPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getPrice() - Method in class org.springframework.batch.sample.domain.trade.Trade
-
- getProcessor() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the process skip count.
- getProcessSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- getProductName() - Method in enum org.springframework.batch.support.DatabaseType
-
- getProperties(JobParameters) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Use the same suffixes to create properties (omitting the string suffix
because it is the default).
- getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
-
The inverse operation: get a Properties
instance.
- getProperties() - Method in class org.springframework.batch.core.jsr.JsrJobContext
-
- getProperties(JobParameters) - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
-
- getProperties() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getProperties(JobParameters) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
-
Convert schedule date to Date, and assume all other parameters can be represented by their default string value.
- getProperties() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
-
- getProperties() - Method in interface org.springframework.batch.item.file.transform.FieldSet
-
Construct name-value pairs from the field names and string values.
- getProperty(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
-
- getProperty(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
-
- getPropertyName() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
-
- getPropertyName() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
-
- getPropertyName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
-
- getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
-
- getPropertyName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
-
- getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
-
- getQuantity() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
-
- getQuantity() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getQuantity() - Method in class org.springframework.batch.sample.domain.trade.Trade
-
- getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
- getReadCount() - Method in class org.springframework.batch.core.StepContribution
-
Public access to the read counter.
- getReadCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items read for this execution
- getReader() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
-
- getReader() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
- getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- getReceivedCount() - Method in class org.springframework.batch.sample.domain.person.PersonService
-
- getReceivedMessages() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
-
- getReceptions() - Method in class org.springframework.batch.core.test.football.Game
-
- getReceptions() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getReceptions() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getReceptions() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getReceptionYards() - Method in class org.springframework.batch.core.test.football.Game
-
- getReceptionYards() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getReceptionYards() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getReceptionYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getRegistrationId() - Method in class org.springframework.batch.sample.domain.order.Customer
-
- getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
-
- getResult(XMLEventWriter) - Static method in class org.springframework.batch.item.xml.StaxUtils
-
- getReturnedCount() - Method in class org.springframework.batch.sample.domain.person.PersonService
-
- getRollbackClassifier() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Convenience method to get an exception classifier based on the provided transaction attributes.
- getRollbackCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of rollbacks for this execution
- getRootElementAttributes() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get attributes of the root element.
- getRootTagName() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get the tag name of the root element.
- getRootTagNamespace() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get the namespace of the root element.
- getRootTagNamespacePrefix() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get the namespace prefix of the root element.
- getRunningExecutions(String) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getRunningExecutions(String) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Get the id values of all the running
JobExecutions
with the given job name.
- getRunningExecutions(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getRushes() - Method in class org.springframework.batch.core.test.football.Game
-
- getRushes() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getRushes() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getRushes() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getRushYards() - Method in class org.springframework.batch.core.test.football.Game
-
- getRushYards() - Method in class org.springframework.batch.core.test.football.PlayerSummary
-
- getRushYards() - Method in class org.springframework.batch.sample.domain.football.Game
-
- getRushYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
-
- getSelectClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
- getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
-
- getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
-
- getShipper() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
-
- getShipperId() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
-
- getShipping() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getShippingAddress() - Method in class org.springframework.batch.sample.domain.order.Order
-
- getShippingInfo() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
-
- getShippingPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
-
- getShippingTypeId() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
-
- getSimpleStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getSimpleStepBuilder(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
-
- getSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getSkipCount() - Method in class org.springframework.batch.core.StepExecution
-
- getSkipLimit() - Method in exception org.springframework.batch.core.step.skip.SkipLimitExceededException
-
- getSkipListeners() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
- getSkips() - Method in class org.springframework.batch.core.step.item.Chunk
-
- getSortKeyPlaceHolder(String) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Returns either a String to be used as the named placeholder for a sort key value (based on the column name)
or a ? for unnamed parameters.
- getSortKeyPlaceHolder(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
The sort key placeholder will vary depending on whether named parameters
or traditional placeholders are used in query strings.
- getSortKeys() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
The sort keys.
- getSortKeys() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
A Map<String, Boolean> of sort columns as the key and boolean for ascending/descending (ascending = true).
- getSortKeysWithoutAliases() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
The sort key (unique single column name) without alias.
- getSortKeysWithoutAliases() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
- getSource(XMLEventReader) - Static method in class org.springframework.batch.item.xml.StaxUtils
-
- getSplitTaskExecutorPropertyValue(BeanDefinitionRegistry) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
-
- getSplitter() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getSql() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
- getSql() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
-
- getSql() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
-
- getStartable(StepExecution, ExecutionContext) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
- getStartedCount() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
-
- getStartedCount() - Method in interface org.springframework.batch.repeat.RepeatContext
-
Public access to a counter for the number of operations attempted.
- getStartLimit() - Method in class org.springframework.batch.core.step.AbstractStep
-
- getStartLimit() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getStartLimit() - Method in interface org.springframework.batch.core.Step
-
- getStartState() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
- getStartTime() - Method in class org.springframework.batch.core.JobExecution
-
- getStartTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
-
- getStartTime() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getStartTime() - Method in class org.springframework.batch.core.StepExecution
-
Gets the time this execution started
- getState() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
-
- getState(String) - Method in interface org.springframework.batch.core.job.flow.Flow
-
Retrieve the State with the given name.
- getState(String) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Retrieve the State with the given name.
- getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Public getter for the State.
- getState() - Method in class org.springframework.batch.sample.domain.order.Address
-
- getStatefulSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
-
- getStatelessSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
-
- getStateMap() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
- getStates() - Method in interface org.springframework.batch.core.job.flow.Flow
-
Convenient accessor for clients needing to explore the states of this
flow.
- getStates() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Convenient accessor for clients needing to explore the states of this
flow.
- getStateTransitionReference(ParserContext, BeanDefinition, String, String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
- getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
-
- getStatus() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
-
- getStatus() - Method in class org.springframework.batch.core.JobExecution
-
- getStatus() - Method in exception org.springframework.batch.core.JobInterruptedException
-
The desired status of the surrounding execution after the interruption.
- getStatus() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current status of this step
- getStep(String, String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
-
Returns the
Step
of the specified job based on its name.
- getStep(String, String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
-
- getStep(String) - Method in class org.springframework.batch.core.job.AbstractJob
-
Retrieve the step with the given name.
- getStep(String) - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Retrieve the step with the given name.
- getStep() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
-
- getStep(String) - Method in class org.springframework.batch.core.job.flow.support.state.StepState
-
- getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
-
- getStep() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
-
- getStep(String) - Method in class org.springframework.batch.core.jsr.step.PartitionStep
-
- getStep() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
The step instance that will be executed in parallel by this handler.
- getStep() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getStep() - Method in interface org.springframework.batch.core.step.StepHolder
-
- getStep(String) - Method in interface org.springframework.batch.core.step.StepLocator
-
- getStep(String) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
-
Look up a bean with the provided name of type
Step
.
- getStepArtifactProperties(String, String) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
-
Obtains the batch Properties
for the provided Step and artifact name.
- getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
-
- getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
-
- getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
-
- getStepContributions() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
-
- getStepContributions() - Method in interface org.springframework.batch.integration.chunk.StepContributionSource
-
Get the currently available contributions and drain the source.
- getStepExecution(Long, Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
- getStepExecution(Long, Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
-
- getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
- getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
-
- getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
- getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
-
- getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
- getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getStepExecution(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
-
Discover a
StepExecution
as a field in the test case or create
one if none is available.
- getStepExecutionAggergator() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
- getStepExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
-
- getStepExecutionCount(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
-
- getStepExecutionCount(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
-
- getStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
-
- getStepExecutionId() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getStepExecutionId() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getStepExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
-
- getStepExecutionListeners() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
-
- getStepExecutions() - Method in class org.springframework.batch.core.JobExecution
-
Accessor for the step executions.
- getStepExecutions(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
-
- getStepExecutionSplitter() - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
- getStepExecutionSummaries(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Summarise the
StepExecution
instances belonging to the
JobExecution
with the supplied id, giving details of status,
start and end times etc.
- getStepExecutionSummaries(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
- getStepName() - Method in class org.springframework.batch.core.jsr.JsrStepContext
-
- getStepName() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
-
- getStepName() - Method in class org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
-
- getStepName() - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
-
The name of the step configuration that will be executed remotely.
- getStepName() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
- getStepName() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current step name identifier.
- getStepName() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
- getStepName() - Method in class org.springframework.batch.core.StepExecution
-
- getStepName() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
-
- getStepNames() - Method in class org.springframework.batch.core.job.AbstractJob
-
Retrieve the step names.
- getStepNames() - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Retrieve the step names.
- getStepNames() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
-
- getStepNames() - Method in class org.springframework.batch.core.job.SimpleJob
-
Convenience method for clients to inspect the steps for this job.
- getStepNames() - Method in class org.springframework.batch.core.jsr.step.PartitionStep
-
- getStepNames() - Method in interface org.springframework.batch.core.step.StepLocator
-
- getStepNames() - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
-
Look in the bean factory for all beans of type
Step
.
- getStepOperations() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to access the step operations that were injected by user.
- getStepOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the step operations to make them available in subclasses.
- getStepProperties(String) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
-
Obtains the Step level properties for the provided Step name.
- getStepRunner() - Method in class org.springframework.batch.test.AbstractJobTests
-
Deprecated.
Convenient method for subclasses to grab a
StepRunner
for running
steps by name.
- getStepRunner() - Method in class org.springframework.batch.test.JobLauncherTestUtils
-
Convenient method for subclasses to grab a
StepRunner
for running
steps by name.
- getStepSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
- getStreams() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
- getString(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the String represented by the provided key.
- getString(String, String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe Getter for the String represented by the provided key.
- getString(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the String represented by the provided key.
- getString(String, String) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the String represented by the provided key with
default value to return if key is not represented.