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

A

abandon(long) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
abandon(long) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Mark the JobExecution as ABANDONED.
abandon(long) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
ABANDONED - org.springframework.batch.core.BatchStatus
 
abandonStepExecution() - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed at the start of a state.
abandonStepExecution() - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
AbstractApplicationContextFactory - org.springframework.batch.core.configuration.support中的类
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
AbstractApplicationContextFactory(Object...) - 类 的构造器org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Create a factory instance with the resource specified.
AbstractBatchConfiguration - org.springframework.batch.core.configuration.annotation中的类
Base Configuration class providing common structure for enabling and using Spring Batch.
AbstractBatchConfiguration() - 类 的构造器org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
AbstractCursorItemReader<T> - 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() - 类 的构造器org.springframework.batch.item.database.AbstractCursorItemReader
 
AbstractFileItemWriter<T> - org.springframework.batch.item.support中的类
Base class for item writers that write data to a file or stream.
AbstractFileItemWriter() - 类 的构造器org.springframework.batch.item.support.AbstractFileItemWriter
 
AbstractFileItemWriter.OutputState - org.springframework.batch.item.support中的类
Encapsulates the runtime state of the writer.
AbstractFlowParser - org.springframework.batch.core.configuration.xml中的类
 
AbstractFlowParser() - 类 的构造器org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
AbstractHibernateQueryProvider<T> - org.springframework.batch.item.database.orm中的类
Abstract Hibernate Query Provider to serve as a base class for all Hibernate Query providers.
AbstractHibernateQueryProvider() - 类 的构造器org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
AbstractItemCountingItemStreamItemReader<T> - org.springframework.batch.item.support中的类
Abstract superclass for ItemReaders that supports restart by storing item count in the ExecutionContext (therefore requires item ordering to be preserved between runs).
AbstractItemCountingItemStreamItemReader() - 类 的构造器org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
AbstractItemStreamItemReader<T> - org.springframework.batch.item.support中的类
Base class for ItemReader implementations.
AbstractItemStreamItemReader() - 类 的构造器org.springframework.batch.item.support.AbstractItemStreamItemReader
 
AbstractItemStreamItemWriter<T> - org.springframework.batch.item.support中的类
Base class for ItemWriter implementations.
AbstractItemStreamItemWriter() - 类 的构造器org.springframework.batch.item.support.AbstractItemStreamItemWriter
 
AbstractJdbcBatchMetadataDao - org.springframework.batch.core.repository.dao中的类
Encapsulates common functionality needed by JDBC batch metadata DAOs - provides jdbcTemplate for subclasses and handles table prefixes.
AbstractJdbcBatchMetadataDao() - 类 的构造器org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
AbstractJob - org.springframework.batch.core.job中的类
Abstract implementation of the Job interface.
AbstractJob() - 类 的构造器org.springframework.batch.core.job.AbstractJob
Default constructor.
AbstractJob(String) - 类 的构造器org.springframework.batch.core.job.AbstractJob
Convenience constructor to immediately add name (which is mandatory but not final).
AbstractJobExplorerFactoryBean - org.springframework.batch.core.explore.support中的类
A FactoryBean that automates the creation of a SimpleJobExplorer.
AbstractJobExplorerFactoryBean() - 类 的构造器org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
AbstractJobRepositoryFactoryBean - org.springframework.batch.core.repository.support中的类
A FactoryBean that automates the creation of a SimpleJobRepository.
AbstractJobRepositoryFactoryBean() - 类 的构造器org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
AbstractJobTests - org.springframework.batch.test中的类
已过时。
(from 2.1) use JobLauncherTestUtils instead
AbstractJobTests() - 类 的构造器org.springframework.batch.test.AbstractJobTests
已过时。
 
AbstractJpaQueryProvider - org.springframework.batch.item.database.orm中的类
Abstract JPA Query Provider to serve as a base class for all JPA Query providers.
AbstractJpaQueryProvider() - 类 的构造器org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
 
AbstractLineTokenizer - 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() - 类 的构造器org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
AbstractListenerFactoryBean<T> - org.springframework.batch.core.listener中的类
FactoryBean implementation that builds a listener based on the various lifecycle methods or annotations that are provided.
AbstractListenerFactoryBean() - 类 的构造器org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
AbstractListenerParser - org.springframework.batch.core.configuration.xml中的类
 
AbstractListenerParser() - 类 的构造器org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
AbstractMethodInvokingDelegator<T> - org.springframework.batch.item.adapter中的类
Superclass for delegating classes which dynamically call a custom method of injected object.
AbstractMethodInvokingDelegator() - 类 的构造器org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper - org.springframework.batch.item.adapter中的异常错误
Used to wrap a Throwable (not an Exception) thrown by a reflectively-invoked delegate.
AbstractNeo4jItemReader<T> - org.springframework.batch.item.data中的类
Restartable ItemReader that reads objects from the graph database Neo4j via a paging technique.
AbstractNeo4jItemReader() - 类 的构造器org.springframework.batch.item.data.AbstractNeo4jItemReader
 
AbstractPaginatedDataItemReader<T> - 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() - 类 的构造器org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
AbstractPagingItemReader<T> - org.springframework.batch.item.database中的类
Abstract ItemStreamReader for to extend when reading database records in a paging fashion.
AbstractPagingItemReader() - 类 的构造器org.springframework.batch.item.database.AbstractPagingItemReader
 
AbstractPartitionHandler - org.springframework.batch.core.partition.support中的类
Base PartitionHandler implementation providing common base features.
AbstractPartitionHandler() - 类 的构造器org.springframework.batch.core.partition.support.AbstractPartitionHandler
 
AbstractSqlPagingQueryProvider - 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() - 类 的构造器org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
AbstractState - org.springframework.batch.core.job.flow.support.state中的类
 
AbstractState(String) - 类 的构造器org.springframework.batch.core.job.flow.support.state.AbstractState
 
AbstractStep - org.springframework.batch.core.step中的类
A Step implementation that provides common behavior to subclasses, including registering and calling listeners.
AbstractStep() - 类 的构造器org.springframework.batch.core.step.AbstractStep
Default constructor.
AbstractStep(String) - 类 的构造器org.springframework.batch.core.step.AbstractStep
Convenient constructor for setting only the name property.
AbstractStepParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <step/> elements inside a job.
AbstractStepParser() - 类 的构造器org.springframework.batch.core.configuration.xml.AbstractStepParser
 
AbstractTaskletStepBuilder<B extends AbstractTaskletStepBuilder<B>> - org.springframework.batch.core.step.builder中的类
Base class for step builders that want to build a TaskletStep.
AbstractTaskletStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
add(XMLEvent) - 类 中的方法org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
add(XMLEvent) - 类 中的方法org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
 
add(XMLEvent) - 类 中的方法org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
 
add(Flow...) - 类 中的方法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) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
add(StepExecution) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
add(W) - 类 中的方法org.springframework.batch.core.step.item.Chunk
Add the item to the chunk.
ADD - org.springframework.batch.sample.domain.trade.CustomerOperation
 
addAll(Collection<StepExecution>) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Save a collection of StepExecutions and each ExecutionContext.
addAll(Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
addApplicationContextFactory(ApplicationContextFactory) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
addColumns(Range) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
Add a column range to the existing list
addColumns(Range, int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
Insert a column range to the existing list
addComment(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Add a string to the list of Strings that indicate commented lines.
addDate(String, Date) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new identifying Date parameter for the given key.
addDate(String, Date, boolean) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new Date parameter for the given key.
addDouble(String, Double) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new identifying Double parameter for the given key.
addDouble(String, Double, boolean) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new Double parameter for the given key.
addExitDescription(String) - 类 中的方法org.springframework.batch.core.ExitStatus
Add an exit description to an existing ExitStatus.
addExitDescription(Throwable) - 类 中的方法org.springframework.batch.core.ExitStatus
Extract the stack trace from the throwable provided and append it to the exist description.
addExitStatus(String) - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
 
addExitStatus(String) - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
addExitStatus(String) - 类 中的方法org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
 
addFailureException(Throwable) - 类 中的方法org.springframework.batch.core.JobExecution
Add the provided throwable to the failure exception list.
addFailureException(Throwable) - 类 中的方法org.springframework.batch.core.StepExecution
 
addFragmentRootElements(String...) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Adds the list of fragments to be used as the root of each chunk to the configuration.
addFragmentRootElements(List<String>) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Adds the list of fragments to be used as the root of each chunk to the configuration.
addIncludedField(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Add an index to the list of fields to be included from the file
ADDITIONAL_SHIPPING_INFO_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
addJobExecutionListener(JobExecutionListener) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addJobParameters(JobParameters) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Copy job parameters into the current state.
addLong(String, Long) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new identifying Long parameter for the given key.
addLong(String, Long, boolean) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new Long parameter for the given key.
addParameter(String, JobParameter) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new JobParameter for the given key.
Address - org.springframework.batch.sample.domain.order中的类
 
Address() - 类 的构造器org.springframework.batch.sample.domain.order.Address
 
ADDRESS_LINE1_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
ADDRESS_LINE2_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
ADDRESSEE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
AddressFieldExtractor - org.springframework.batch.sample.domain.order.internal.extractor中的类
 
AddressFieldExtractor() - 类 的构造器org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
 
AddressFieldSetMapper - org.springframework.batch.sample.domain.order.internal.mapper中的类
 
AddressFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
addStep(Step) - 类 中的方法org.springframework.batch.core.job.SimpleJob
Convenience method for adding a single step to the job.
addStepExecutionListener(StepExecutionListener) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutionListeners(List<JobExecutionListener>) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addStepExecutionListeners(List<StepExecutionListener>) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutions(List<StepExecution>) - 类 中的方法org.springframework.batch.core.JobExecution
Add some step executions.
addStepExecutions(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
addStepExecutions(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
addStepExecutions(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve all the StepExecution for the parent JobExecution.
addString(String, String) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new identifying String parameter for the given key.
addString(String, String, boolean) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Add a new String parameter for the given key.
after(JoinPoint, StepExecution) - 类 中的方法org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
after(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
 
after(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.listener.RepeatListenerSupport
 
after(RepeatContext, RepeatStatus) - 接口 中的方法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) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
AFTER_CHUNK - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_CHUNK - org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_CHUNK_ERROR - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_CHUNK_ERROR - org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_JOB - org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
AFTER_JOB - org.springframework.batch.core.listener.JobListenerMetaData
 
AFTER_PROCESS - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_PROCESS - org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_PROCESS_ERROR - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_READ - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_READ - org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_READ_ERROR - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_STEP - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_STEP - org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_WRITE - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
AFTER_WRITE - org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_WRITE_ERROR - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
afterChunk(ChunkContext) - 接口 中的方法org.springframework.batch.core.ChunkListener
Callback after the chunk is executed, outside the transaction.
afterChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.ChunkListenerAdapter
 
afterChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
afterChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.ChunkListenerSupport
 
afterChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in reverse order.
afterChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
afterChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
AfterChunk - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called after a chunk is executed.

Expected signature: void afterChunk(ChunkContext context)
afterChunkError(ChunkContext) - 接口 中的方法org.springframework.batch.core.ChunkListener
Callback after a chunk has been marked for rollback.
afterChunkError(ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.ChunkListenerAdapter
 
afterChunkError(ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
afterChunkError(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.ChunkListenerSupport
 
afterChunkError(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in reverse order.
afterChunkError(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
afterChunkError(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
AfterChunkError - 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)
afterJob(JobExecution) - 接口 中的方法org.springframework.batch.core.JobExecutionListener
Callback after completion of a job.
afterJob(JobExecution) - 类 中的方法org.springframework.batch.core.jsr.JobListenerAdapter
 
afterJob(JobExecution) - 类 中的方法org.springframework.batch.core.listener.CompositeJobExecutionListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterJob(JobExecution) - 类 中的方法org.springframework.batch.core.listener.JobExecutionListenerSupport
 
AfterJob - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called after a Job has completed.
afterProcess(I, O) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
afterProcess(T, S) - 接口 中的方法org.springframework.batch.core.ItemProcessListener
Called after ItemProcessor.process(Object) returns.
afterProcess(T, S) - 类 中的方法org.springframework.batch.core.jsr.ItemProcessListenerAdapter
 
afterProcess(T, S) - 类 中的方法org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterProcess(T, S) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
afterProcess(T, S) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
AfterProcess - 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)
afterPropertiesSet() - 类 中的方法org.springframework.batch.container.jms.BatchMessageListenerContainer
Set up interceptor with provided advice on the BatchMessageListenerContainer.receiveAndExecute(Object, Session, MessageConsumer) method.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.configuration.support.DefaultJobLoader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Make sure the registry is set before use.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
Check mandatory properties (name).
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.job.AbstractJob
Assert mandatory properties: JobRepository.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.job.CompositeJobParametersValidator
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.job.DefaultJobParametersValidator
Check that there are no overlaps between required and optional keys.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.job.flow.FlowStep
Ensure that the flow is set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
Locate start state and pre-populate data structures needed for execution.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.job.SimpleStepHandler
Check mandatory properties (jobRepository).
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.jsr.job.JsrStepHandler
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.jsr.JsrJobParametersConverter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobLauncher
Ensure the required dependencies of a JobRepository have been set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
Check mandatory properties.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
Assert that mandatory properties are set (stepExecutionSplitter, partitionHandler) and delegate top superclass.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check mandatory properties (step name, job repository and partitioner).
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Check mandatory properties.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.step.job.JobStep
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Assert that the callable is set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.integration.async.AsyncItemProcessor
Check mandatory properties (the AsyncItemProcessor.setDelegate(ItemProcessor)).
afterPropertiesSet() - 类 中的方法org.springframework.batch.integration.async.AsyncItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Asserts that mandatory properties are set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.integration.step.DelegateStep
Check mandatory properties (delegate).
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
Checks mandatory properties
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.data.MongoItemReader
Checks mandatory properties
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.data.Neo4jItemWriter
Checks mandatory properties
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.data.RepositoryItemWriter
Check mandatory properties - there must be a repository.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
Check mandatory properties.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.HibernateItemWriter
Check mandatory properties - there must be a sessionFactory.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Check mandatory properties - there must be a SimpleJdbcTemplate and an SQL statement plus a parameter source.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
Check mandatory properties.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.JpaItemWriter
Check mandatory properties - there must be an entityManagerFactory.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.database.support.ListPreparedStatementSetter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.FlatFileItemWriter
Assert that mandatory properties (lineAggregator) are set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Check that precisely one of type or prototype bean name is specified.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.mapping.DefaultLineMapper
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineTokenizer
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.jms.JmsItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.json.JsonFileItemWriter
Assert that mandatory properties (jsonObjectMarshaller) are set.
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.KeyValueItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.ldif.LdifReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
Check mandatory properties (mailSender).
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.mail.SimpleMailMessageItemWriter
Check mandatory properties (mailSender).
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.support.CompositeItemProcessor
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.support.ScriptItemProcessor
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.support.SynchronizedItemStreamReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.validator.BeanValidatingItemProcessor
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.validator.SpringValidator
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.item.validator.ValidatingItemProcessor
 
afterPropertiesSet() - 类 中的方法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() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Apply the provided properties to create a delegate handler.
afterPropertiesSet() - 类 中的方法org.springframework.batch.sample.common.StagingItemListener
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.sample.common.StagingItemProcessor
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.sample.common.StagingItemReader
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Check mandatory properties (delegate).
afterPropertiesSet() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.support.SystemPropertyInitializer
Sets the System property with the provided name and default value.
afterPropertiesSet() - 类 中的方法org.springframework.batch.test.DataSourceInitializer
 
afterPropertiesSet() - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
 
afterRead(I) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
afterRead(Long) - 类 中的方法org.springframework.batch.sample.common.StagingItemListener
 
afterRead(T) - 接口 中的方法org.springframework.batch.core.ItemReadListener
Called after ItemReader.read().
afterRead(T) - 类 中的方法org.springframework.batch.core.jsr.ItemReadListenerAdapter
 
afterRead(T) - 类 中的方法org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterRead(T) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
afterRead(T) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
AfterRead - 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)
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.jsr.StepListenerAdapter
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in reverse order, respecting and prioritizing those that implement Ordered.
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.StepExecutionListenerSupport
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
 
afterStep(StepExecution) - 接口 中的方法org.springframework.batch.core.StepExecutionListener
Give a listener a chance to modify the exit status from a step.
afterStep(StepExecution) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.sample.common.StagingItemReader
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.sample.common.StagingItemWriter
 
afterStep(StepExecution) - 类 中的方法org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
AfterStep - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called after a Step has completed.
afterTestClass(TestContext) - 类 中的方法org.springframework.batch.test.JobScopeTestExecutionListener
 
afterTestClass(TestContext) - 类 中的方法org.springframework.batch.test.StepScopeTestExecutionListener
 
afterTestMethod(TestContext) - 类 中的方法org.springframework.batch.test.JobScopeTestExecutionListener
 
afterTestMethod(TestContext) - 类 中的方法org.springframework.batch.test.StepScopeTestExecutionListener
 
afterWrite(List<? extends O>) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
afterWrite(List<? extends S>) - 接口 中的方法org.springframework.batch.core.ItemWriteListener
Called after ItemWriter.write(java.util.List) This will be called before any transaction is committed, and before ChunkListener.afterChunk(ChunkContext)
afterWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
afterWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
afterWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
AfterWrite - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called after an item is passed to an ItemWriter

Expected signature: void afterWrite(List<?
aggregate(Collection<FlowExecution>) - 接口 中的方法org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
 
aggregate(Collection<FlowExecution>) - 类 中的方法org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
Aggregate all of the FlowExecutionStatuses of the FlowExecutions into one status.
aggregate(Collection<T>) - 类 中的方法org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
 
aggregate(List<?>) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
aggregate(StepExecution, Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.jsr.partition.support.JsrStepExecutionAggregator
 
aggregate(StepExecution, Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
Aggregates the input executions into the result StepExecution.
aggregate(StepExecution, Collection<StepExecution>) - 类 中的方法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>) - 接口 中的方法org.springframework.batch.core.partition.support.StepExecutionAggregator
Take the inputs and aggregate, putting the aggregates into the result.
aggregate(Order) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
 
aggregate(T) - 类 中的方法org.springframework.batch.item.file.transform.ExtractorLineAggregator
Extract fields from the given item using the FieldExtractor and then aggregate them.
aggregate(T) - 接口 中的方法org.springframework.batch.item.file.transform.LineAggregator
Create a string from the value provided.
aggregate(T) - 类 中的方法org.springframework.batch.item.file.transform.PassThroughLineAggregator
Simply convert to a String with toString().
AggregateItem<T> - 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(boolean, boolean) - 类 的构造器org.springframework.batch.sample.domain.multiline.AggregateItem
 
AggregateItem(T) - 类 的构造器org.springframework.batch.sample.domain.multiline.AggregateItem
 
AggregateItemFieldSetMapper<T> - org.springframework.batch.sample.domain.multiline中的类
Delegating mapper to convert form a vanilla FieldSetMapper to one that returns AggregateItem instances for consumption by the AggregateItemReader.
AggregateItemFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
 
AggregateItemReader<T> - 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() - 类 的构造器org.springframework.batch.sample.domain.multiline.AggregateItemReader
 
aggregator(StepExecutionAggregator) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide a step execution aggregator for aggregating partitioned step executions into a single result for the PartitionStep itself.
aggregator(StepExecutionAggregator) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
Alignment - org.springframework.batch.item.file.transform中的枚举
 
allowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
allowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
allowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
allowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
AlwaysSkipItemSkipPolicy - org.springframework.batch.core.step.skip中的类
Implementation of the SkipPolicy interface that will always return that an item should be skipped.
AlwaysSkipItemSkipPolicy() - 类 的构造器org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
AmqpItemReader<T> - org.springframework.batch.item.amqp中的类
AMQP ItemReader implementation using an AmqpTemplate to receive and/or convert messages.
AmqpItemReader(AmqpTemplate) - 类 的构造器org.springframework.batch.item.amqp.AmqpItemReader
Initialize the AmqpItemReader.
AmqpItemReaderBuilder<T> - org.springframework.batch.item.amqp.builder中的类
A builder implementation for the AmqpItemReader
AmqpItemReaderBuilder() - 类 的构造器org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
 
AmqpItemWriter<T> - org.springframework.batch.item.amqp中的类
AMQP ItemWriter implementation using an AmqpTemplate to send messages.
AmqpItemWriter(AmqpTemplate) - 类 的构造器org.springframework.batch.item.amqp.AmqpItemWriter
 
AmqpItemWriterBuilder<T> - org.springframework.batch.item.amqp.builder中的类
A builder implementation for the AmqpItemWriter
AmqpItemWriterBuilder() - 类 的构造器org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
 
AmqpMessageProducer - org.springframework.batch.sample.rabbitmq.amqp中的类
Simple producer class that sends String messages to the configured queue to be processed.
amqpTemplate(AmqpTemplate) - 类 中的方法org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
Establish the amqpTemplate to be used by the AmqpItemReader.
amqpTemplate(AmqpTemplate) - 类 中的方法org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
Establish the amqpTemplate to be used by the AmqpItemWriter.
and(boolean) - 枚举 中的方法org.springframework.batch.repeat.RepeatStatus
 
and(ExitStatus) - 类 中的方法org.springframework.batch.core.ExitStatus
Create a new ExitStatus with a logical combination of the exit code, and a concatenation of the descriptions.
AnnotationMethodResolver - 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>) - 类 的构造器org.springframework.batch.support.AnnotationMethodResolver
Create a MethodResolver for the specified Method-level annotation type.
append - 类 中的变量org.springframework.batch.item.support.AbstractFileItemWriter
 
append(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true and the file exists, the output will be appended to the existing file.
append(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true and the file exists, the output will be appended to the existing file.
ApplicationContextFactory - org.springframework.batch.core.configuration.support中的接口
Factory for the creation of ApplicationContexts.
ApplicationContextJobFactory - 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) - 类 的构造器org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
 
apply(StepContribution) - 类 中的方法org.springframework.batch.core.StepExecution
On successful execution just before a chunk commit, this method should be called.
applyConfiguration(SimpleStepBuilder<T, S>) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
applyConfiguration(SimpleStepBuilder<T, S>) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
applyListenerScope(String, BeanDefinitionRegistry) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
applyStatementSettings(PreparedStatement) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Prepare the given JDBC Statement (or PreparedStatement or CallableStatement), applying statement settings such as fetch size, max rows, and query timeout.
arguments(List<?>) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Arguments to be passed to the data providing method.
ArrayFieldSetMapper - org.springframework.batch.item.file.mapping中的类
A basic array mapper, returning the values backing a fieldset.
ArrayFieldSetMapper() - 类 的构造器org.springframework.batch.item.file.mapping.ArrayFieldSetMapper
 
ARTIFACT - org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
 
ASCENDING - org.springframework.batch.item.database.Order
 
AssertFile - org.springframework.batch.test中的类
This class can be used to assert that two files are the same.
AssertFile() - 类 的构造器org.springframework.batch.test.AssertFile
 
assertFileEquals(File, File) - 类 中的静态方法org.springframework.batch.test.AssertFile
 
assertFileEquals(Resource, Resource) - 类 中的静态方法org.springframework.batch.test.AssertFile
 
assertLineCount(int, File) - 类 中的静态方法org.springframework.batch.test.AssertFile
 
assertLineCount(int, Resource) - 类 中的静态方法org.springframework.batch.test.AssertFile
 
assertUpdates(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
If set to true, confirms that every insert results in the update of at least one row in the database.
AsynchronousFailureException - org.springframework.batch.integration.chunk中的异常错误
Exception indicating that a failure or early completion condition was detected in a remote worker.
AsynchronousFailureException(String) - 异常错误 的构造器org.springframework.batch.integration.chunk.AsynchronousFailureException
Create a new AsynchronousFailureException based on a message.
AsynchronousFailureException(String, Throwable) - 异常错误 的构造器org.springframework.batch.integration.chunk.AsynchronousFailureException
Create a new AsynchronousFailureException based on a message and another exception.
AsyncItemProcessor<I,​O> - org.springframework.batch.integration.async中的类
An ItemProcessor that delegates to a nested processor and in the background.
AsyncItemProcessor() - 类 的构造器org.springframework.batch.integration.async.AsyncItemProcessor
 
AsyncItemWriter<T> - org.springframework.batch.integration.async中的类
 
AsyncItemWriter() - 类 的构造器org.springframework.batch.integration.async.AsyncItemWriter
 
attributeNames() - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
AutomaticJobRegistrar - org.springframework.batch.core.configuration.support中的类
Loads and unloads Jobs when the application context is created and destroyed.
AutomaticJobRegistrar() - 类 的构造器org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
autoregisterBeansForNamespace(ParserContext, Object) - 类 中的静态方法org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
 

B

backOffPolicy(BackOffPolicy) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide a backoff policy to prevent items being retried immediately (e.g. in case the failure was caused by a remote resource failure that might take some time to be resolved).
backOffPolicy(BackOffPolicy) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
BaseContextListFactoryBean - 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() - 类 的构造器org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
BasicPartitioner - org.springframework.batch.sample.remotepartitioning中的类
Simple partitioner for demonstration purpose.
BasicPartitioner() - 类 的构造器org.springframework.batch.sample.remotepartitioning.BasicPartitioner
 
BatchArtifactType - org.springframework.batch.core.jsr.configuration.support中的枚举
Enum to identify batch artifact types.
BatchConfigurationException - org.springframework.batch.core.configuration中的异常错误
Represents an error has occurred in the configuration of base batch infrastructure (creation of a JobRepository for example.
BatchConfigurationException(Throwable) - 异常错误 的构造器org.springframework.batch.core.configuration.BatchConfigurationException
 
BatchConfigurationSelector - org.springframework.batch.core.configuration.annotation中的类
Base Configuration class providing common structure for enabling and using Spring Batch.
BatchConfigurationSelector() - 类 的构造器org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
BatchConfigurer - org.springframework.batch.core.configuration.annotation中的接口
Strategy interface for users to provide as a factory for custom components needed by a Batch system.
BatchIntegrationConfiguration - org.springframework.batch.integration.config.annotation中的类
Base configuration class for Spring Batch Integration factory beans.
BatchIntegrationConfiguration(JobRepository, JobExplorer, PlatformTransactionManager) - 类 的构造器org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
BatchIntegrationNamespaceHandler - org.springframework.batch.integration.config.xml中的类
The namespace handler for the Spring Batch Integration namespace.
BatchIntegrationNamespaceHandler() - 类 的构造器org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
 
BatchletAdapter - org.springframework.batch.core.jsr.step.batchlet中的类
 
BatchletAdapter(Batchlet) - 类 的构造器org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
 
BatchletParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser for the <batchlet /> tag defined in JSR-352.
BatchletParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.BatchletParser
 
BatchletStep - org.springframework.batch.core.jsr.step中的类
Special sub class of the TaskletStep for use with JSR-352 jobs.
BatchletStep(String, BatchPropertyContext) - 类 的构造器org.springframework.batch.core.jsr.step.BatchletStep
 
BatchMessageListenerContainer - 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() - 类 的构造器org.springframework.batch.container.jms.BatchMessageListenerContainer
 
BatchMessageListenerContainer.ContainerDelegate - org.springframework.batch.container.jms中的接口
 
BatchParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser used to parse the batch.xml file as defined in JSR-352.
BatchParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.BatchParser
 
BatchPropertyBeanPostProcessor - 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() - 类 的构造器org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
BatchPropertyContext - org.springframework.batch.core.jsr.configuration.support中的类
Context object to hold parsed JSR-352 batch properties, mapping properties to beans / "batch artifacts".
BatchPropertyContext() - 类 的构造器org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
 
BatchRetryTemplate - org.springframework.batch.core.step.item中的类
A special purpose retry template that deals specifically with multi-valued stateful retry.
BatchRetryTemplate() - 类 的构造器org.springframework.batch.core.step.item.BatchRetryTemplate
 
BatchScopeSupport - org.springframework.batch.core.scope中的类
ScopeSupport.
BatchScopeSupport() - 类 的构造器org.springframework.batch.core.scope.BatchScopeSupport
 
BatchScopeSupport.Scopifier - 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 - org.springframework.batch.core中的枚举
Enumeration representing the status of an Execution.
BatchTestContextCustomizer - org.springframework.batch.test.context中的类
ContextCustomizer implementation that adds batch test utility classes (JobLauncherTestUtils and JobRepositoryTestUtils) as beans in the test context.
BatchTestContextCustomizer() - 类 的构造器org.springframework.batch.test.context.BatchTestContextCustomizer
 
BatchTestContextCustomizerFactory - org.springframework.batch.test.context中的类
BatchTestContextCustomizerFactory() - 类 的构造器org.springframework.batch.test.context.BatchTestContextCustomizerFactory
 
BeanDefinitionUtils - org.springframework.batch.core.configuration.xml中的类
 
BeanDefinitionUtils() - 类 的构造器org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
beanFactory(BeanFactory) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the bean factory.
beanFactory(BeanFactory) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the bean factory.
beanFactory(BeanFactory) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configures the BeanFactory used to create the beans that are returned as items.
BeanFactoryStepLocator - org.springframework.batch.integration.partition中的类
A StepLocator implementation that just looks in its enclosing bean factory for components of type Step.
BeanFactoryStepLocator() - 类 的构造器org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
beanMapped() - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
beanMapperStrict(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
If set to true, mapping will fail if the FieldSet contains fields that cannot be mapped to the bean.
BeanPropertyItemSqlParameterSourceProvider<T> - 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() - 类 的构造器org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
 
beanRowMapper(Class<T>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Creates a BeanPropertyRowMapper to be used as your RowMapper.
BeanValidatingItemProcessor<T> - org.springframework.batch.item.validator中的类
A ValidatingItemProcessor that uses the Bean Validation API (JSR-303) to validate items.
BeanValidatingItemProcessor() - 类 的构造器org.springframework.batch.item.validator.BeanValidatingItemProcessor
Create a new instance of BeanValidatingItemProcessor with the default configuration.
BeanValidatingItemProcessor(LocalValidatorFactoryBean) - 类 的构造器org.springframework.batch.item.validator.BeanValidatingItemProcessor
Create a new instance of BeanValidatingItemProcessor.
BeanWrapperFieldExtractor<T> - org.springframework.batch.item.file.transform中的类
This is a field extractor for a java bean.
BeanWrapperFieldExtractor() - 类 的构造器org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
BeanWrapperFieldSetMapper<T> - org.springframework.batch.item.file.mapping中的类
FieldSetMapper implementation based on bean property paths.
BeanWrapperFieldSetMapper() - 类 的构造器org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
before(JoinPoint, StepExecution) - 类 中的方法org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
before(RepeatContext) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
 
before(RepeatContext) - 类 中的方法org.springframework.batch.repeat.listener.RepeatListenerSupport
 
before(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.RepeatListener
Called by the framework before each batch item.
before(RepeatContext) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
BEFORE_CHUNK - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
BEFORE_CHUNK - org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_JOB - org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
BEFORE_JOB - org.springframework.batch.core.listener.JobListenerMetaData
 
BEFORE_PROCESS - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
BEFORE_PROCESS - org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_READ - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
BEFORE_READ - org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_STEP - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
BEFORE_STEP - org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_WRITE - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
BEFORE_WRITE - org.springframework.batch.core.listener.StepListenerMetaData
 
beforeChunk(ChunkContext) - 接口 中的方法org.springframework.batch.core.ChunkListener
Callback before the chunk is executed, but inside the transaction.
beforeChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.ChunkListenerAdapter
 
beforeChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
beforeChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.ChunkListenerSupport
 
beforeChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
beforeChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeChunk(ChunkContext) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
BeforeChunk - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called before a chunk is executed.
beforeJob(JobExecution) - 接口 中的方法org.springframework.batch.core.JobExecutionListener
Callback before a job executes.
beforeJob(JobExecution) - 类 中的方法org.springframework.batch.core.jsr.JobListenerAdapter
 
beforeJob(JobExecution) - 类 中的方法org.springframework.batch.core.listener.CompositeJobExecutionListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeJob(JobExecution) - 类 中的方法org.springframework.batch.core.listener.JobExecutionListenerSupport
 
BeforeJob - 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.
beforeProcess(I) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
beforeProcess(T) - 接口 中的方法org.springframework.batch.core.ItemProcessListener
beforeProcess(T) - 类 中的方法org.springframework.batch.core.jsr.ItemProcessListenerAdapter
 
beforeProcess(T) - 类 中的方法org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeProcess(T) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeProcess(T) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
BeforeProcess - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called before an item is passed to an ItemProcessor

Expected signature: void beforeProcess(T item)
beforeRead() - 接口 中的方法org.springframework.batch.core.ItemReadListener
Called before ItemReader.read()
beforeRead() - 类 中的方法org.springframework.batch.core.jsr.ItemReadListenerAdapter
 
beforeRead() - 类 中的方法org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeRead() - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
beforeRead() - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeRead() - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
BeforeRead - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called before an item is read from an ItemReader

Expected signature: void beforeRead()
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.jsr.StepListenerAdapter
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
Copy attributes from the JobParameters to the StepExecutionContext, if not already present.
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.StepExecutionListenerSupport
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Set up a SimpleCompletionPolicy with a commit interval taken from the JobParameters.
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Get a reference to StepExecution for interrupt checks during system command execution.
beforeStep(StepExecution) - 接口 中的方法org.springframework.batch.core.StepExecutionListener
Initialize the state of the listener with the StepExecution from the current scope.
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.sample.common.InfiniteLoopWriter
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.sample.common.StagingItemReader
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.sample.common.StagingItemWriter
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
beforeStep(StepExecution) - 类 中的方法org.springframework.batch.sample.support.SummaryFooterCallback
 
BeforeStep - 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.
beforeTestClass(TestContext) - 类 中的方法org.springframework.batch.test.JobScopeTestExecutionListener
 
beforeTestClass(TestContext) - 类 中的方法org.springframework.batch.test.StepScopeTestExecutionListener
 
beforeTestMethod(TestContext) - 类 中的方法org.springframework.batch.test.JobScopeTestExecutionListener
 
beforeTestMethod(TestContext) - 类 中的方法org.springframework.batch.test.StepScopeTestExecutionListener
 
beforeWrite(List<? extends O>) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
beforeWrite(List<? extends S>) - 接口 中的方法org.springframework.batch.core.ItemWriteListener
beforeWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
beforeWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeWrite(List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
BeforeWrite - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called before an item is passed to an ItemWriter

Expected signature: void beforeWrite(List<?
begin(T) - 类 中的方法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 - org.springframework.batch.sample.domain.order.internal.mapper中的类
 
BillingFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
BillingInfo - org.springframework.batch.sample.domain.order中的类
 
BillingInfo() - 类 的构造器org.springframework.batch.sample.domain.order.BillingInfo
 
BillingInfoFieldExtractor - org.springframework.batch.sample.domain.order.internal.extractor中的类
 
BillingInfoFieldExtractor() - 类 的构造器org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
 
bind(JobFactory, Map<String, ?>) - 类 中的方法org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and register it with the JobRegistry.
BrokerConfiguration - org.springframework.batch.sample.remotepartitioning中的类
 
BrokerConfiguration() - 类 的构造器org.springframework.batch.sample.remotepartitioning.BrokerConfiguration
 
BufferedReaderFactory - 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() - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Validate the current state of the builder and build a flow.
build() - 类 中的方法org.springframework.batch.core.job.builder.FlowJobBuilder
Build a job that executes the flow provided, normally composed of other steps.
build() - 类 中的方法org.springframework.batch.core.job.builder.JobFlowBuilder
Build a flow and inject it into the parent builder.
build() - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
 
build() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrBatchletStepBuilder
Build the step from the components collected by the fluent setters.
build() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
Build the step from the components collected by the fluent setters.
build() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
build() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
Build the step from the components collected by the fluent setters.
build() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Build the step from the components collected by the fluent setters.
build() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
build() - 类 中的方法org.springframework.batch.core.step.builder.FlowStepBuilder
Build a step that executes the flow provided, normally composed of other steps.
build() - 类 中的方法org.springframework.batch.core.step.builder.JobStepBuilder
Build a step from the job provided.
build() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
build() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Build a step with the reader, writer, processor as provided.
build() - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Build a master TaskletStep.
build() - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Create an IntegrationFlow with a ChunkProcessorChunkHandler configured as a service activator listening to the input channel and replying on the output channel.
build() - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
build() - 类 中的方法org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
Validates and builds a AmqpItemReader.
build() - 类 中的方法org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
Validates and builds a AmqpItemWriter.
build() - 类 中的方法org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Validates and builds a GemfireItemWriter.
build() - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Validates and builds a MongoItemReader.
build() - 类 中的方法org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Validates and builds a MongoItemWriter.
build() - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Returns a fully constructed Neo4jItemReader.
build() - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
Validates and builds a Neo4jItemWriter.
build() - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
build() - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
build() - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Returns a fully constructed HibernateCursorItemReader.
build() - 类 中的方法org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
Returns a fully built HibernateItemWriter
build() - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Returns a fully constructed HibernatePagingItemReader.
build() - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Validates configuration and builds the JdbcBatchItemWriter.
build() - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Validates configuration and builds a new reader instance.
build() - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Provides a completely built instance of the JdbcPagingItemReader
build() - 类 中的方法org.springframework.batch.item.database.builder.JpaItemWriterBuilder
Returns a fully built JpaItemWriter.
build() - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Returns a fully constructed JpaPagingItemReader.
build() - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Validates configuration and builds a new reader instance
build() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Builds the FlatFileItemReader.
build() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
build() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
build() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Validates and builds a FlatFileItemWriter.
build() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
 
build() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
 
build() - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
build() - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
build() - 类 中的方法org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
Returns a fully constructed JmsItemReader.
build() - 类 中的方法org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
Returns a fully constructed JmsItemWriter.
build() - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Validate the configuration and build a new JsonFileItemWriter.
build() - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Validate the configuration and build a new JsonItemReader.
build() - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Returns a fully constructed LdifReader.
build() - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Returns a fully constructed MappingLdifReader.
build() - 类 中的方法org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
Returns a fully constructed SimpleMailMessageItemWriter.
build() - 类 中的方法org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
Returns a fully constructed ClassifierCompositeItemProcessor.
build() - 类 中的方法org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
Returns a fully constructed ClassifierCompositeItemWriter.
build() - 类 中的方法org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
Returns a fully constructed CompositeItemProcessor.
build() - 类 中的方法org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
Returns a fully constructed CompositeItemWriter.
build() - 类 中的方法org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Returns a fully constructed ScriptItemProcessor.
build() - 类 中的方法org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
Returns a fully constructed SingleItemPeekableItemReader.
build() - 类 中的方法org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
Returns a fully constructed SynchronizedItemStreamReader.
build() - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Validates the configuration and builds a new StaxEventItemReader
build() - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Returns a configured StaxEventItemWriter
buildSortClause(Map<String, Order>) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generates ORDER BY attributes based on the sort keys.
buildSortClause(AbstractSqlPagingQueryProvider) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generates ORDER BY attributes based on the sort keys.
buildSortConditions(AbstractSqlPagingQueryProvider, StringBuilder) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Appends the where conditions required to query for the subsequent pages.

C

CallableTaskletAdapter - org.springframework.batch.core.step.tasklet中的类
Adapts a Callable<RepeatStatus> to the Tasklet interface.
CallableTaskletAdapter() - 类 的构造器org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
 
canContinue(RepeatStatus) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Check return value from batch operation.
canRetry(RetryContext) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
CENTER - org.springframework.batch.item.file.transform.Alignment
 
checkInterrupted(StepExecution) - 接口 中的方法org.springframework.batch.core.step.StepInterruptionPolicy
Has the job been interrupted?
checkInterrupted(StepExecution) - 类 中的方法org.springframework.batch.core.step.ThreadStepInterruptionPolicy
Returns if the current job lifecycle has been interrupted by checking if the current thread is interrupted.
CheckpointAlgorithmAdapter - org.springframework.batch.jsr.repeat中的类
Wrapper for the CheckpointAlgorithm to be used via the rest of the framework.
CheckpointAlgorithmAdapter(CheckpointAlgorithm) - 类 的构造器org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
CheckpointSupport - org.springframework.batch.jsr.item中的类
Provides support for JSR-352 checkpointing.
CheckpointSupport(String) - 类 的构造器org.springframework.batch.jsr.item.CheckpointSupport
 
Child - org.springframework.batch.sample.domain.person中的类
 
Child() - 类 的构造器org.springframework.batch.sample.domain.person.Child
 
chunk(int) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets the chunk size or commit interval for this step.
chunk(int) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the size provided.
chunk(int) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
chunk(int) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
chunk(CompletionPolicy) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets a completion policy for the chunk processing.
chunk(CompletionPolicy) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the completion policy provided.
chunk(CompletionPolicy) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
chunk(CompletionPolicy) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
Chunk<W> - 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() - 类 的构造器org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>) - 类 的构造器org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>, List<SkipWrapper<W>>) - 类 的构造器org.springframework.batch.core.step.item.Chunk
 
Chunk.ChunkIterator - org.springframework.batch.core.step.item中的类
Special iterator for a chunk providing the Chunk.ChunkIterator.remove(Throwable) method for dynamically removing an item and adding it to the skips.
ChunkContext - 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) - 类 的构造器org.springframework.batch.core.scope.context.ChunkContext
 
ChunkElementParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <chunk/> element inside a step.
ChunkElementParser() - 类 的构造器org.springframework.batch.core.configuration.xml.ChunkElementParser
 
ChunkHandler<T> - org.springframework.batch.integration.chunk中的接口
Interface for a remote worker in the Remote Chunking pattern.
ChunkIterator(List<W>) - 类 的构造器org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
ChunkListener - org.springframework.batch.core中的接口
Listener interface for the lifecycle of a chunk.
ChunkListenerAdapter - org.springframework.batch.core.jsr中的类
Wrapper class to adapt the ChunkListener to a ChunkListener.
ChunkListenerAdapter(ChunkListener) - 类 的构造器org.springframework.batch.core.jsr.ChunkListenerAdapter
 
chunkListeners - 类 中的变量org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
ChunkListenerSupport - org.springframework.batch.core.listener中的类
Basic support implementation of ChunkListener
ChunkListenerSupport() - 类 的构造器org.springframework.batch.core.listener.ChunkListenerSupport
 
ChunkMessageChannelItemWriter<T> - org.springframework.batch.integration.chunk中的类
 
ChunkMessageChannelItemWriter() - 类 的构造器org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
ChunkMonitor - org.springframework.batch.core.step.item中的类
Manage the offset data between the last successful commit and updates made to an input chunk.
ChunkMonitor() - 类 的构造器org.springframework.batch.core.step.item.ChunkMonitor
 
ChunkMonitor.ChunkMonitorData - org.springframework.batch.core.step.item中的类
 
ChunkMonitorData(int, int) - 类 的构造器org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
chunkOperations(RepeatOperations) - 类 中的方法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.
chunkOperations(RepeatOperations) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
ChunkOrientedTasklet<I> - org.springframework.batch.core.step.item中的类
A Tasklet implementing variations on read-process-write item handling.
ChunkOrientedTasklet(ChunkProvider<I>, ChunkProcessor<I>) - 类 的构造器org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
ChunkParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser for the <chunk /> element as specified in JSR-352.
ChunkParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.ChunkParser
 
ChunkProcessor<I> - org.springframework.batch.core.step.item中的接口
Interface defined for processing Chunks.
ChunkProcessorChunkHandler<S> - org.springframework.batch.integration.chunk中的类
ChunkProcessorChunkHandler() - 类 的构造器org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
ChunkProvider<T> - org.springframework.batch.core.step.item中的接口
Interface for providing Chunks to be processed, used by the ChunkOrientedTasklet
ChunkRequest<T> - 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) - 类 的构造器org.springframework.batch.integration.chunk.ChunkRequest
 
ChunkResponse - org.springframework.batch.integration.chunk中的类
Encapsulates a response to processing a chunk of items, summarising the result as a StepContribution.
ChunkResponse(boolean, int, Long, StepContribution) - 类 的构造器org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution, String) - 类 的构造器org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution, String, boolean) - 类 的构造器org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(int, Long, StepContribution) - 类 的构造器org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(ChunkResponse, boolean) - 类 的构造器org.springframework.batch.integration.chunk.ChunkResponse
 
chunkSize - 类 中的变量org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
CITY_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
classifier(Classifier<? super I, ItemProcessor<?, ? extends O>>) - 类 中的方法org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
Establishes the classifier that will determine which ItemProcessor to use.
classifier(Classifier<T, ItemWriter<? super T>>) - 类 中的方法org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
Establish the classifier to be used for the selection of which ItemWriter to use.
Classifier - org.springframework.batch.support.annotation中的注释类型
Mark a method as capable of classifying its input to an instance of its output.
ClassifierCompositeItemProcessor<I,​O> - org.springframework.batch.item.support中的类
Calls one of a collection of ItemProcessors, based on a router pattern implemented through the provided Classifier.
ClassifierCompositeItemProcessor() - 类 的构造器org.springframework.batch.item.support.ClassifierCompositeItemProcessor
 
ClassifierCompositeItemProcessorBuilder<I,​O> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified ClassifierCompositeItemProcessor.
ClassifierCompositeItemProcessorBuilder() - 类 的构造器org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
 
ClassifierCompositeItemWriter<T> - 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() - 类 的构造器org.springframework.batch.item.support.ClassifierCompositeItemWriter
 
ClassifierCompositeItemWriterBuilder<T> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified ClassifierCompositeItemWriter.
ClassifierCompositeItemWriterBuilder() - 类 的构造器org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
 
ClassPathXmlApplicationContextFactory - org.springframework.batch.core.configuration.support中的类
已过时。
ClassPathXmlApplicationContextFactory(Resource) - 类 的构造器org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
已过时。
Create an application context factory for the resource specified.
ClasspathXmlApplicationContextsFactoryBean - org.springframework.batch.core.configuration.support中的类
A convenient factory for creating a set of ApplicationContextFactory components from a set of resources.
ClasspathXmlApplicationContextsFactoryBean() - 类 的构造器org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
 
ClassPathXmlJobRegistry - org.springframework.batch.core.configuration.support中的类
已过时。
in version 2.1, please us AutomaticJobRegistrar instead
ClassPathXmlJobRegistry() - 类 的构造器org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
已过时。
 
cleanupOnClose() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
 
cleanupOnClose() - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
Close the cursor and database connection.
cleanupOnClose() - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Close the cursor and database connection.
clear() - 类 中的方法org.springframework.batch.core.configuration.support.DefaultJobLoader
Unregister all the jobs and close all the contexts created by this loader.
clear() - 接口 中的方法org.springframework.batch.core.configuration.support.JobLoader
Unregister all the jobs and close all the contexts created by this loader.
clear() - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
clear() - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
clear() - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
clear() - 类 中的方法org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
clear() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Convenience method to clear all the map DAOs globally, removing all entities.
clear() - 类 中的方法org.springframework.batch.core.step.item.Chunk
Clear the items down to signal that we are done.
clear() - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Clear the session if stateful.
clear() - 类 中的静态方法org.springframework.batch.repeat.support.RepeatSynchronizationManager
Clear the current context at the end of a batch - should only be used by RepeatOperations implementations.
clear() - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
clear() - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
clearDirtyFlag() - 类 中的方法org.springframework.batch.item.ExecutionContext
Clears the dirty flag.
clearSession(boolean) - 类 中的方法org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
If set to false, the Session will not be cleared at the end of the chunk.
clearSkips() - 类 中的方法org.springframework.batch.core.step.item.Chunk
Clear only the skips list.
close() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContextFactoryBean
Used to remove the JobContext for the current thread.
close() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Clean up the context at the end of a step execution.
close() - 类 中的静态方法org.springframework.batch.core.scope.context.JobSynchronizationManager
Method for unregistering the current context - should always and only be used by in conjunction with a matching JobSynchronizationManager.register(JobExecution) to ensure that JobSynchronizationManager.getContext() always returns the correct value.
close() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Clean up the context at the end of a step execution.
close() - 类 中的静态方法org.springframework.batch.core.scope.context.StepSynchronizationManager
Method for unregistering the current context - should always and only be used by in conjunction with a matching StepSynchronizationManager.register(StepExecution) to ensure that StepSynchronizationManager.getContext() always returns the correct value.
close() - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Method for unregistering the current context - should always and only be used by in conjunction with a matching SynchronizationManagerSupport.register(Object) to ensure that SynchronizationManagerSupport.getContext() always returns the correct value.
close() - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
close() - 类 中的方法org.springframework.batch.integration.async.AsyncItemWriter
 
close() - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
close() - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Close the open session (stateful or otherwise).
close() - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
Close the MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream) reader and reset instance variable values.
close() - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
 
close() - 接口 中的方法org.springframework.batch.item.ItemStream
If any resources are needed for the stream to operate they need to be destroyed here.
close() - 类 中的方法org.springframework.batch.item.ItemStreamSupport
No-op.
close() - 类 中的方法org.springframework.batch.item.json.GsonJsonObjectReader
 
close() - 类 中的方法org.springframework.batch.item.json.JacksonJsonObjectReader
 
close() - 接口 中的方法org.springframework.batch.item.json.JsonObjectReader
Close the input resource.
close() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
 
close() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
Close the open resource and reset counters.
close() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
close() - 类 中的方法org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to close.
close() - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
 
close() - 类 中的方法org.springframework.batch.item.support.SingleItemPeekableItemReader
If the delegate is an ItemStream, just pass the call on, otherwise reset the peek cache.
close() - 类 中的方法org.springframework.batch.item.support.SynchronizedItemStreamReader
 
close() - 类 中的方法org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
close() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Flush and close the output source.
close() - 类 中的方法org.springframework.batch.jsr.item.CheckpointSupport
 
close() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
close() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Allow resources to be cleared, especially in destruction callbacks.
close() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
close() - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
close(C) - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
close(FlowExecution) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
close(ExecutionContext) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the end of a step (right at the end of the finally block), to close or release resources.
close(ExecutionContext) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
 
close(RepeatContext) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
 
close(RepeatContext) - 类 中的方法org.springframework.batch.repeat.listener.RepeatListenerSupport
 
close(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.RepeatListener
Called once at the end of a complete batch, after normal or abnormal completion (i.e. even after an exception).
close(RepeatContext) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
close(RetryContext, RetryCallback<T, E>, Throwable) - 类 中的方法org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
If retry is exhausted set up some state in the context that can be used to signal that the exception should be handled.
collection(String) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Establish an optional collection that can be queried.
collection(String) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Set the name of the Mongo collection to be written to.
ColumnMapItemPreparedStatementSetter - 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() - 类 的构造器org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
columnMapped() - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
ColumnRangePartitioner - org.springframework.batch.sample.common中的类
Simple minded partitioner for a range of values of a column in a database table.
ColumnRangePartitioner() - 类 的构造器org.springframework.batch.sample.common.ColumnRangePartitioner
 
columns(Range[]) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
The column ranges for each field
CommandLineJobRunner - org.springframework.batch.core.launch.support中的类
Basic launcher for starting jobs from the command line.
CommandLineJobRunner() - 类 的构造器org.springframework.batch.core.launch.support.CommandLineJobRunner
 
comments(String...) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Set an array of Strings that indicate lines that are comments (and therefore skipped by the reader).
commit(T, T) - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
Take the working copy state and commit it back to the original target.
CommonJobProperties() - 类 的构造器org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
CommonJobProperties(JobBuilderHelper.CommonJobProperties) - 类 的构造器org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
CommonsLoggingInvalidCustomerLogger - org.springframework.batch.sample.domain.trade.internal中的类
 
CommonsLoggingInvalidCustomerLogger() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
CommonStepProperties() - 类 的构造器org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
CommonStepProperties(StepBuilderHelper.CommonStepProperties) - 类 的构造器org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
COMPANY_NAME_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
comparator(Comparator<Resource>) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
Used to order the injected resources, by default compares Resource.getFilename() values.
compare(StateTransition, StateTransition) - 类 中的方法org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
compare(Resource, Resource) - 类 中的方法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) - 类 中的方法org.springframework.batch.core.ExitStatus
 
compareTo(FlowExecution) - 类 中的方法org.springframework.batch.core.job.flow.FlowExecution
Create an ordering on FlowExecution instances by comparing their statuses.
compareTo(FlowExecutionStatus) - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
Create an ordering on FlowExecutionStatus instances by comparing their statuses.
COMPLETED - org.springframework.batch.core.BatchStatus
The order of the status values is significant because it can be used to aggregate a set of status values - the result should be the maximum value.
COMPLETED - 类 中的静态变量org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing.
COMPLETED - 类 中的静态变量org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
CompletionPolicy - org.springframework.batch.repeat中的接口
Interface for batch completion policies, to enable batch operations to strategise normal completion conditions.
CompletionPolicySupport - org.springframework.batch.repeat.policy中的类
Very simple base class for CompletionPolicy implementations.
CompletionPolicySupport() - 类 的构造器org.springframework.batch.repeat.policy.CompletionPolicySupport
 
CompositeBatchContext(RepeatContext, List<RepeatContext>) - 类 的构造器org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
 
CompositeChunkListener - org.springframework.batch.core.listener中的类
 
CompositeChunkListener() - 类 的构造器org.springframework.batch.core.listener.CompositeChunkListener
 
CompositeCompletionPolicy - org.springframework.batch.repeat.policy中的类
Composite policy that loops through a list of delegate policies and answers calls by a consensus.
CompositeCompletionPolicy() - 类 的构造器org.springframework.batch.repeat.policy.CompositeCompletionPolicy
 
CompositeCompletionPolicy.CompositeBatchContext - org.springframework.batch.repeat.policy中的类
Composite context that knows about the policies and contexts is was created with.
CompositeCustomerUpdateLineTokenizer - org.springframework.batch.sample.domain.trade中的类
Composite LineTokenizer that delegates the tokenization of a line to one of two potential tokenizers.
CompositeCustomerUpdateLineTokenizer() - 类 的构造器org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
CompositeExceptionHandler - org.springframework.batch.repeat.exception中的类
Composite ExceptionHandler that loops though a list of delegates.
CompositeExceptionHandler() - 类 的构造器org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
CompositeItemProcessListener<T,​S> - org.springframework.batch.core.listener中的类
 
CompositeItemProcessListener() - 类 的构造器org.springframework.batch.core.listener.CompositeItemProcessListener
 
CompositeItemProcessor<I,​O> - org.springframework.batch.item.support中的类
Composite ItemProcessor that passes the item through a sequence of injected ItemTransformers (return value of previous transformation is the entry value of the next).

Note the user is responsible for injecting a chain of ItemProcessors that conforms to declared input and output types.
CompositeItemProcessor() - 类 的构造器org.springframework.batch.item.support.CompositeItemProcessor
 
CompositeItemProcessorBuilder<I,​O> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified CompositeItemProcessorBuilder.
CompositeItemProcessorBuilder() - 类 的构造器org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
 
CompositeItemReadListener<T> - org.springframework.batch.core.listener中的类
 
CompositeItemReadListener() - 类 的构造器org.springframework.batch.core.listener.CompositeItemReadListener
 
CompositeItemStream - org.springframework.batch.item.support中的类
Simple ItemStream that delegates to a list of other streams.
CompositeItemStream() - 类 的构造器org.springframework.batch.item.support.CompositeItemStream
 
CompositeItemWriteListener<S> - org.springframework.batch.core.listener中的类
 
CompositeItemWriteListener() - 类 的构造器org.springframework.batch.core.listener.CompositeItemWriteListener
 
CompositeItemWriter<T> - org.springframework.batch.item.support中的类
Calls a collection of ItemWriters in fixed-order sequence.

The implementation is thread-safe if all delegates are thread-safe.
CompositeItemWriter() - 类 的构造器org.springframework.batch.item.support.CompositeItemWriter
 
CompositeItemWriterBuilder<T> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified CompositeItemWriter.
CompositeItemWriterBuilder() - 类 的构造器org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
 
CompositeJobExecutionListener - org.springframework.batch.core.listener中的类
 
CompositeJobExecutionListener() - 类 的构造器org.springframework.batch.core.listener.CompositeJobExecutionListener
 
CompositeJobParametersValidator - org.springframework.batch.core.job中的类
Composite JobParametersValidator that passes the job parameters through a sequence of injected JobParametersValidators
CompositeJobParametersValidator() - 类 的构造器org.springframework.batch.core.job.CompositeJobParametersValidator
 
CompositeRepeatListener - org.springframework.batch.repeat.listener中的类
Allows a user to register one or more RepeatListeners to be notified on batch events.
CompositeRepeatListener() - 类 的构造器org.springframework.batch.repeat.listener.CompositeRepeatListener
 
CompositeRetryProcessListener - org.springframework.batch.core.listener中的类
Composite class holding RetryProcessListener's.
CompositeRetryProcessListener() - 类 的构造器org.springframework.batch.core.listener.CompositeRetryProcessListener
 
CompositeRetryReadListener - org.springframework.batch.core.listener中的类
Composite class holding RetryReadListener's.
CompositeRetryReadListener() - 类 的构造器org.springframework.batch.core.listener.CompositeRetryReadListener
 
CompositeRetryWriteListener - org.springframework.batch.core.listener中的类
Composite class holding RetryWriteListener's.
CompositeRetryWriteListener() - 类 的构造器org.springframework.batch.core.listener.CompositeRetryWriteListener
 
CompositeSkipListener<T,​S> - org.springframework.batch.core.listener中的类
 
CompositeSkipListener() - 类 的构造器org.springframework.batch.core.listener.CompositeSkipListener
 
CompositeSkipPolicy - org.springframework.batch.core.step.skip中的类
 
CompositeSkipPolicy() - 类 的构造器org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
CompositeSkipPolicy(SkipPolicy[]) - 类 的构造器org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
CompositeStepExecutionListener - org.springframework.batch.core.listener中的类
 
CompositeStepExecutionListener() - 类 的构造器org.springframework.batch.core.listener.CompositeStepExecutionListener
 
concurrent() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to determine if the step is concurrent.
ConfigurableSystemProcessExitCodeMapper - org.springframework.batch.core.step.tasklet中的类
Maps exit codes to ExitStatus according to injected map.
ConfigurableSystemProcessExitCodeMapper() - 类 的构造器org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
connectionFactory() - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
connectionFactory() - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
connectionFactory() - 类 中的方法org.springframework.batch.sample.remotepartitioning.BrokerConfiguration
 
containsKey(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Indicates whether or not a key is represented in this context.
containsValue(Object) - 类 中的方法org.springframework.batch.item.ExecutionContext
Indicates whether or not a value is represented in this context.
CONTINUABLE - org.springframework.batch.repeat.RepeatStatus
Indicates that processing can continue.
continueIf(boolean) - 枚举 中的静态方法org.springframework.batch.repeat.RepeatStatus
 
ConversionException - org.springframework.batch.item.file.transform中的异常错误
 
ConversionException(String) - 异常错误 的构造器org.springframework.batch.item.file.transform.ConversionException
 
convert(V) - 类 中的方法org.springframework.batch.item.SpELItemKeyMapper
 
CoreNamespaceHandler - org.springframework.batch.core.configuration.xml中的类
 
CoreNamespaceHandler() - 类 的构造器org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
CoreNamespacePostProcessor - org.springframework.batch.core.configuration.xml中的类
Post-process jobs and steps defined using the batch namespace to inject dependencies.
CoreNamespacePostProcessor() - 类 的构造器org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
CoreNamespaceUtils - org.springframework.batch.core.configuration.xml中的类
Utility methods used in parsing of the batch core namespace
CoreNamespaceUtils() - 类 的构造器org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
 
COUNT - 类 中的静态变量org.springframework.batch.repeat.policy.CountingCompletionPolicy
Session key for global counter.
CountingBatchContext(RepeatContext) - 类 的构造器org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
CountingCompletionPolicy - org.springframework.batch.repeat.policy中的类
Abstract base class for policies that need to count the number of occurrences of some event (e.g. an exception type in the context), and terminate based on a limit for the counter.
CountingCompletionPolicy() - 类 的构造器org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
CountingCompletionPolicy.CountingBatchContext - org.springframework.batch.repeat.policy中的类
 
countParameterPlaceholders(String, List<String>) - 类 中的静态方法org.springframework.batch.item.database.JdbcParameterUtils
Count the occurrences of the character placeholder in an SQL string sql.
COUNTRY_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
create(String[]) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSetFactory
Create a FieldSet with anonymous tokens.
create(String[]) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSetFactory
Create a FieldSet with anonymous tokens.
create(String[], String[]) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSetFactory
Create a FieldSet with named tokens.
create(String[], String[]) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSetFactory
Create a FieldSet with named tokens.
create(Resource, String) - 接口 中的方法org.springframework.batch.item.file.BufferedReaderFactory
Create a BufferedReader for reading String items from the provided resource.
create(Resource, String) - 类 中的方法org.springframework.batch.item.file.DefaultBufferedReaderFactory
 
create(Resource, String) - 类 中的方法org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
 
createAppendOnlyTransactionalList() - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createAppendOnlyTransactionalMap() - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createAppendOnlyTransactionalSet() - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createApplicationContext() - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Creates an ApplicationContext from the provided path.
createApplicationContext() - 接口 中的方法org.springframework.batch.core.configuration.support.ApplicationContextFactory
 
createApplicationContext(ConfigurableApplicationContext, Object...) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
createApplicationContext(ConfigurableApplicationContext, Object...) - 类 中的方法org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
 
createBinder(Object) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Create a binder for the target object.
createBuilder(String) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
createBuilder(String) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
createChunkOperations() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
createChunkProcessor() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
Provides a JSR-352 specific implementation of a ChunkProcessor for use within the ChunkOrientedTasklet
createChunkProcessor() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createChunkProvider() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
createChunkProvider() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createContextCustomizer(Class<?>, List<ContextConfigurationAttributes>) - 类 中的方法org.springframework.batch.test.context.BatchTestContextCustomizerFactory
 
createEndStateTransition(State) - 类 中的静态方法org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createEndStateTransition(State, String) - 类 中的静态方法org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createExecutionContextDao() - 类 中的方法org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createExecutionContextDao() - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createExecutionContextDao() - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createExecutionContextDao() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createExecutionContextDao() - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createExecutionContextDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createFaultTolerantStep() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createFlowStep() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createInternalState(RepeatContext) - 类 中的方法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) - 类 中的方法org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
createJob() - 接口 中的方法org.springframework.batch.core.configuration.JobFactory
 
createJob() - 类 中的方法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() - 类 中的方法org.springframework.batch.core.configuration.support.ReferenceJobFactory
Just return the instance passed in on initialization.
createJobExecution() - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with default parameters.
createJobExecution(Long) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, Long, Long) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, Long, Long, String) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, Long, Long, JobParameters) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, JobParameters) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Create a JobExecution for a given Job and JobParameters.
createJobExecution(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
createJobExecution(JobInstance, JobParameters, String) - 接口 中的方法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(JobInstance, JobParameters, String) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
createJobExecutionDao() - 类 中的方法org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createJobExecutionDao() - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobExecutionDao() - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createJobExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createJobExecutions(int) - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
Use the JobRepository to create some JobExecution instances each with a single step execution.
createJobExecutions(String, String[], int) - 类 中的方法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.
createJobExecutionWithStepExecutions(Long, Collection<String>) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided with attached step executions.
createJobExplorer() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createJobInstance() - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobInstance with default parameters.
createJobInstance(String, Long) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a JobInstance with the parameters provided.
createJobInstance(String, JobParameters) - 类 中的方法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) - 接口 中的方法org.springframework.batch.core.repository.dao.JobInstanceDao
Create a JobInstance with given name and parameters.
createJobInstance(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
createJobInstance(String, JobParameters) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Create a new JobInstance with the name and job parameters provided.
createJobInstance(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
createJobInstanceDao() - 类 中的方法org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createJobInstanceDao() - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobInstanceDao() - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createJobInstanceDao() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobInstanceDao() - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobInstanceDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createJobLauncher() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createJobRepository() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createNewContext(E, BatchPropertyContext) - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
createNewFile(File) - 类 中的静态方法org.springframework.batch.item.util.FileUtils
Create a new file if it doesn't already exist.
createNewStepState(State, String, String) - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
Provides an extension point to provide alternative StepState implementations within a SimpleFlow
createNewStepState(State, String, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrFlowFactoryBean
 
createOutputNameFromInput(StepExecution) - 类 中的方法org.springframework.batch.sample.common.OutputFileListener
 
createPartitionStep() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createPartitionStep() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
createQuery() - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Open appropriate type of hibernate session and create the query.
createQuery() - 类 中的方法org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
Create an NativeQuery from the session provided (preferring stateless if both are available).
createQuery() - 接口 中的方法org.springframework.batch.item.database.orm.HibernateQueryProvider
Create the query object which type will be determined by the underline implementation (e.g.
createQuery() - 类 中的方法org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
createQuery() - 接口 中的方法org.springframework.batch.item.database.orm.JpaQueryProvider
Create the query object.
createRetryOperations() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createScopedProxy(String, BeanDefinition, BeanDefinitionRegistry, boolean) - 类 中的静态方法org.springframework.batch.core.scope.BatchScopeSupport
Wrap a target bean definition in a proxy that defers initialization until after the StepContext is available.
createSemaphore() - 类 中的方法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() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createSkipPolicy() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createSqlParameterSource(T) - 类 中的方法org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
Provide parameter values in an BeanPropertySqlParameterSource based on values from the provided item.
createSqlParameterSource(T) - 接口 中的方法org.springframework.batch.item.database.ItemSqlParameterSourceProvider
Provide parameter values in an SqlParameterSource based on values from the provided item.
createState(List<?>) - 类 中的静态方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
createState(List<?>, Classifier<? super Throwable, Boolean>) - 类 中的静态方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
createStateTransition(State, String) - 类 中的静态方法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) - 类 中的静态方法org.springframework.batch.core.job.flow.support.StateTransition
Create a new StateTransition specification from one State to another (by name).
createStaxResult() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the STAX result.
createStepContribution() - 类 中的方法org.springframework.batch.core.StepExecution
Factory method for StepContribution.
createStepExecution() - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution with default parameters.
createStepExecution(String) - 类 中的方法org.springframework.batch.core.JobExecution
Register a step execution with the current job execution.
createStepExecution(String, Long) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution with the parameters provided.
createStepExecution(JobExecution, String, Long) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution with the parameters provided.
createStepExecution(JobParameters) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution and all its parent entities with default values, but using the JobParameters provided.
createStepExecution(JobParameters, ExecutionContext) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution and all its parent entities with default values, but using the ExecutionContext and JobParameters provided.
createStepExecution(ExecutionContext) - 类 中的静态方法org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution and all its parent entities with default values, but using the ExecutionContext provided.
createStepExecutionDao() - 类 中的方法org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createStepExecutionDao() - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createStepExecutionDao() - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createStepExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createStepExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createStepExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createTask(Step, StepExecution) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
Creates the task executing the given step in the context of the given execution.
createTask(Step, StepExecution) - 类 中的方法org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Creates the task executing the given step in the context of the given execution.
createTasklet() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
createTasklet() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
createTasklet() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new chunk oriented tasklet with reader, writer and processor as provided.
createTasklet() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
createTasklet() - 类 中的方法org.springframework.batch.core.step.builder.TaskletStepBuilder
 
createTaskletStep() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createTaskletStep() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
createTransactionalList() - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalList(List<T>) - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalMap() - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalMap(Map<K, V>) - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalSet() - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalSet(Set<T>) - 类 中的静态方法org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransition(FlowExecutionStatus, String, String, String, String, BeanDefinition, ParserContext, boolean) - 类 中的静态方法org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
createTransition(FlowExecutionStatus, String, String, String, BeanDefinition, ParserContext, boolean) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
createXmlEventFactory() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the event factory.
createXmlEventWriter(XMLOutputFactory, Writer) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the writer.
createXmlInputFactory() - 类 中的静态方法org.springframework.batch.item.xml.StaxUtils
 
createXmlOutputFactory() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the factory.
CREDIT_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
CREDIT_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
currentItemCount(int) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Index for the current item.
currentItemCount(int) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Index for the current item.
customEditors(Map<Class<?>, PropertyEditor>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Register custom type converters for beans being mapped.
Customer - org.springframework.batch.sample.domain.order中的类
 
Customer - org.springframework.batch.sample.domain.order.internal.xml中的类
An XML customer.
Customer() - 类 的构造器org.springframework.batch.sample.domain.order.Customer
 
Customer() - 类 的构造器org.springframework.batch.sample.domain.order.internal.xml.Customer
 
CUSTOMER_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
CUSTOMER_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
CUSTOMER_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
CustomerCredit - org.springframework.batch.sample.domain.trade中的类
 
CustomerCredit() - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerCredit
 
CustomerCredit(int, String, BigDecimal) - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerCredit
 
CustomerCreditDao - org.springframework.batch.sample.domain.trade中的接口
Interface for writing customer's credit information to output.
CustomerCreditFieldSetMapper - org.springframework.batch.sample.domain.trade.internal中的类
 
CustomerCreditFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
CustomerCreditIncreaseProcessor - org.springframework.batch.sample.domain.trade.internal中的类
Increases customer's credit by a fixed amount.
CustomerCreditIncreaseProcessor() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
CustomerCreditItemWriter - org.springframework.batch.sample.domain.trade.internal中的类
Delegates actual writing to a custom DAO.
CustomerCreditItemWriter() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
 
CustomerCreditRepository - org.springframework.batch.sample.data中的接口
 
CustomerCreditRowMapper - org.springframework.batch.sample.domain.trade.internal中的类
 
CustomerCreditRowMapper() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
CustomerCreditUpdatePreparedStatementSetter - org.springframework.batch.sample.domain.trade.internal中的类
 
CustomerCreditUpdatePreparedStatementSetter() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
CustomerCreditUpdateWriter - org.springframework.batch.sample.domain.trade.internal中的类
 
CustomerCreditUpdateWriter() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
CustomerDao - org.springframework.batch.sample.domain.trade中的接口
 
CustomerDebit - org.springframework.batch.sample.domain.trade中的类
 
CustomerDebit() - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerDebit
 
CustomerDebitDao - org.springframework.batch.sample.domain.trade中的接口
Interface for writing CustomerDebitDao object to arbitrary output.
CustomerDebitRowMapper - org.springframework.batch.sample.domain.trade.internal中的类
 
CustomerDebitRowMapper() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
CustomerFieldExtractor - org.springframework.batch.sample.domain.order.internal.extractor中的类
 
CustomerFieldExtractor() - 类 的构造器org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
 
CustomerFieldSetMapper - org.springframework.batch.sample.domain.order.internal.mapper中的类
 
CustomerFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
CustomerOperation - org.springframework.batch.sample.domain.trade中的枚举
Enum representing on of 3 possible actions on a customer update: Add, update, or delete
CustomerUpdate - org.springframework.batch.sample.domain.trade中的类
Immutable Value Object representing an update to the customer as stored in the database.
CustomerUpdate(CustomerOperation, String, BigDecimal) - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerUpdate
 
CustomerUpdateFieldSetMapper - org.springframework.batch.sample.domain.trade中的类
FieldSetMapper for mapping to a CustomerUpdate.
CustomerUpdateFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
 
CustomerUpdateProcessor - org.springframework.batch.sample.domain.trade中的类
 
CustomerUpdateProcessor() - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
CustomerUpdateWriter - org.springframework.batch.sample.domain.trade中的类
 
CustomerUpdateWriter - org.springframework.batch.sample.domain.trade.internal中的类
Transforms Trade to a CustomerDebit and asks DAO delegate to write the result.
CustomerUpdateWriter() - 类 的构造器org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
CustomerUpdateWriter() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
customizeContext(ConfigurableApplicationContext, MergedContextConfiguration) - 类 中的方法org.springframework.batch.test.context.BatchTestContextCustomizer
 

D

DatabaseType - org.springframework.batch.support中的枚举
Enum representing a database type, such as DB2 or oracle.
DataFieldMaxValueIncrementerFactory - org.springframework.batch.item.database.support中的接口
Factory for creating DataFieldMaxValueIncrementer implementations based upon a provided string.
dataSource - 类 中的变量org.springframework.batch.core.jsr.JsrJobParametersConverter
 
dataSource() - 类 中的方法org.springframework.batch.sample.config.DataSourceConfiguration
 
dataSource() - 类 中的方法org.springframework.batch.sample.remotepartitioning.DataSourceConfiguration
 
dataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Configure the DataSource to be used.
dataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The DataSource to read from
dataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The DataSource to query against.
dataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The DataSource to read from
DataSourceConfiguration - org.springframework.batch.sample.config中的类
 
DataSourceConfiguration - org.springframework.batch.sample.remotepartitioning中的类
 
DataSourceConfiguration() - 类 的构造器org.springframework.batch.sample.config.DataSourceConfiguration
 
DataSourceConfiguration() - 类 的构造器org.springframework.batch.sample.remotepartitioning.DataSourceConfiguration
 
DataSourceInitializer - org.springframework.batch.test中的类
Wrapper for a DataSource that can run scripts on start up and shut down.
DataSourceInitializer() - 类 的构造器org.springframework.batch.test.DataSourceInitializer
 
DATE - org.springframework.batch.core.JobParameter.ParameterType
 
DATE_TYPE - 类 中的静态变量org.springframework.batch.core.converter.DefaultJobParametersConverter
 
DB2 - org.springframework.batch.support.DatabaseType
 
DB2AS400 - org.springframework.batch.support.DatabaseType
 
Db2PagingQueryProvider - org.springframework.batch.item.database.support中的类
DB2 implementation of a PagingQueryProvider using database specific features.
Db2PagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
DB2VSE - org.springframework.batch.support.DatabaseType
 
DB2ZOS - org.springframework.batch.support.DatabaseType
 
DEBUG - org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Key for Classifier signalling that the throwable should be logged at debug level.
decide(JobExecution, StepExecution) - 接口 中的方法org.springframework.batch.core.job.flow.JobExecutionDecider
Strategy for branching an execution based on the state of an ongoing JobExecution.
decide(JobExecution, StepExecution) - 类 中的方法org.springframework.batch.sample.loop.LimitDecider
 
DECISION_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
DecisionParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <decision/> elements inside a job.
DecisionParser() - 类 的构造器org.springframework.batch.core.configuration.xml.DecisionParser
 
DecisionState - org.springframework.batch.core.job.flow.support.state中的类
State that requires a decider to make the status decision.
DecisionState(JobExecutionDecider, String) - 类 的构造器org.springframework.batch.core.job.flow.support.state.DecisionState
 
DecisionStep - org.springframework.batch.core.jsr.step中的类
Implements a Step to follow the rules for a decision state as defined by JSR-352.
DecisionStep(Decider) - 类 的构造器org.springframework.batch.core.jsr.step.DecisionStep
 
DecisionStepFactoryBean - org.springframework.batch.core.jsr.configuration.xml中的类
FactoryBean for creating a DecisionStep.
DecisionStepFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
DEFAULT_CHARSET - 类 中的静态变量org.springframework.batch.item.file.FlatFileItemReader
 
DEFAULT_CHARSET - 类 中的静态变量org.springframework.batch.item.support.AbstractFileItemWriter
 
DEFAULT_CHUNK_SIZE - 类 中的静态变量org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
DEFAULT_COMMENT_PREFIXES - 类 中的静态变量org.springframework.batch.item.file.FlatFileItemReader
 
DEFAULT_ENCODING - 类 中的静态变量org.springframework.batch.item.xml.StaxEventItemWriter
 
DEFAULT_EXIT_MESSAGE_LENGTH - 类 中的静态变量org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
DEFAULT_JOB_EXECUTION_ID - 类 中的静态变量org.springframework.batch.test.MetaDataInstanceFactory
The default id for a job execution (123L)
DEFAULT_JOB_INSTANCE_ID - 类 中的静态变量org.springframework.batch.test.MetaDataInstanceFactory
The default id for a job instance (12L)
DEFAULT_JOB_NAME - 类 中的静态变量org.springframework.batch.test.MetaDataInstanceFactory
The default name for a job ("job")
DEFAULT_LINE_SEPARATOR - 类 中的静态变量org.springframework.batch.item.support.AbstractFileItemWriter
 
DEFAULT_MAX_SKIPS_ON_READ - 类 中的静态变量org.springframework.batch.core.step.item.FaultTolerantChunkProvider
Hard limit for number of read skips in the same chunk.
DEFAULT_QUOTE_CHARACTER - 类 中的静态变量org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a " character used to escape delimiters or line endings.
DEFAULT_ROOT_TAG_NAME - 类 中的静态变量org.springframework.batch.item.xml.StaxEventItemWriter
 
DEFAULT_STEP_EXECUTION_ID - 类 中的静态变量org.springframework.batch.test.MetaDataInstanceFactory
The default id for a step execution (1234L)
DEFAULT_STEP_NAME - 类 中的静态变量org.springframework.batch.test.MetaDataInstanceFactory
The default name for a step ("step")
DEFAULT_SUFFIX - 类 中的静态变量org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Default value for record terminator suffix.
DEFAULT_TABLE_PREFIX - 类 中的静态变量org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Default value for the table prefix property.
DEFAULT_THROTTLE_LIMIT - 类 中的静态变量org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Default limit for maximum number of concurrent unfinished results allowed by the template.
DEFAULT_TIMEOUT - 类 中的静态变量org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default timeout value in milliseconds (the value equivalent to 30 seconds).
DEFAULT_TRANSACTIONAL - 类 中的静态变量org.springframework.batch.item.support.AbstractFileItemWriter
 
DEFAULT_XML_VERSION - 类 中的静态变量org.springframework.batch.item.xml.StaxEventItemWriter
 
DefaultBatchConfigurer - org.springframework.batch.core.configuration.annotation中的类
 
DefaultBatchConfigurer() - 类 的构造器org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
DefaultBatchConfigurer(DataSource) - 类 的构造器org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
DefaultBufferedReaderFactory - org.springframework.batch.item.file中的类
 
DefaultBufferedReaderFactory() - 类 的构造器org.springframework.batch.item.file.DefaultBufferedReaderFactory
 
DefaultDataFieldMaxValueIncrementerFactory - org.springframework.batch.item.database.support中的类
Default implementation of the DataFieldMaxValueIncrementerFactory interface.
DefaultDataFieldMaxValueIncrementerFactory(DataSource) - 类 的构造器org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
DefaultExceptionHandler - org.springframework.batch.repeat.exception中的类
Default implementation of ExceptionHandler - just re-throws the exception it encounters.
DefaultExceptionHandler() - 类 的构造器org.springframework.batch.repeat.exception.DefaultExceptionHandler
 
DefaultExecutionContextSerializer - org.springframework.batch.core.repository.dao中的类
An implementation of the ExecutionContextSerializer using the default serialization implementations from Spring (DefaultSerializer and DefaultDeserializer).
DefaultExecutionContextSerializer() - 类 的构造器org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
 
DefaultFieldSet - org.springframework.batch.item.file.transform中的类
Default implementation of FieldSet using Java using Java primitive and standard types and utilities.
DefaultFieldSet(String[]) - 类 的构造器org.springframework.batch.item.file.transform.DefaultFieldSet
Create a FieldSet with anonymous tokens.
DefaultFieldSet(String[], String[]) - 类 的构造器org.springframework.batch.item.file.transform.DefaultFieldSet
Create a FieldSet with named tokens.
DefaultFieldSetFactory - org.springframework.batch.item.file.transform中的类
Default implementation of FieldSetFactory with no special knowledge of the FieldSet required.
DefaultFieldSetFactory() - 类 的构造器org.springframework.batch.item.file.transform.DefaultFieldSetFactory
 
DefaultFragmentEventReader - org.springframework.batch.item.xml.stax中的类
Default implementation of FragmentEventReader
DefaultFragmentEventReader(XMLEventReader) - 类 的构造器org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
Caches the StartDocument event for later use.
DefaultItemFailureHandler - org.springframework.batch.core.step.item中的类
Default implementation of the ItemListenerSupport class that writes all exceptions via commons logging.
DefaultItemFailureHandler() - 类 的构造器org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
DefaultJobKeyGenerator - org.springframework.batch.core中的类
Default implementation of the JobKeyGenerator interface.
DefaultJobKeyGenerator() - 类 的构造器org.springframework.batch.core.DefaultJobKeyGenerator
 
DefaultJobLoader - org.springframework.batch.core.configuration.support中的类
Default implementation of JobLoader.
DefaultJobLoader - org.springframework.batch.sample.launch中的类
 
DefaultJobLoader() - 类 的构造器org.springframework.batch.core.configuration.support.DefaultJobLoader
Default constructor useful for declarative configuration.
DefaultJobLoader() - 类 的构造器org.springframework.batch.sample.launch.DefaultJobLoader
 
DefaultJobLoader(JobRegistry) - 类 的构造器org.springframework.batch.core.configuration.support.DefaultJobLoader
Creates a job loader with the job registry provided.
DefaultJobLoader(JobRegistry, StepRegistry) - 类 的构造器org.springframework.batch.core.configuration.support.DefaultJobLoader
Creates a job loader with the job and step registries provided.
DefaultJobParametersConverter - org.springframework.batch.core.converter中的类
Converter for JobParameters instances using a simple naming convention for property keys.
DefaultJobParametersConverter() - 类 的构造器org.springframework.batch.core.converter.DefaultJobParametersConverter
 
DefaultJobParametersExtractor - 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() - 类 的构造器org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
DefaultJobParametersValidator - org.springframework.batch.core.job中的类
Default implementation of JobParametersValidator.
DefaultJobParametersValidator() - 类 的构造器org.springframework.batch.core.job.DefaultJobParametersValidator
Convenient default constructor for unconstrained validation.
DefaultJobParametersValidator(String[], String[]) - 类 的构造器org.springframework.batch.core.job.DefaultJobParametersValidator
Create a new validator with the required and optional job parameter keys provided.
DefaultLineMapper<T> - org.springframework.batch.item.file.mapping中的类
Two-phase LineMapper implementation consisting of tokenization of the line into FieldSet followed by mapping to item.
DefaultLineMapper() - 类 的构造器org.springframework.batch.item.file.mapping.DefaultLineMapper
 
DefaultMailErrorHandler - org.springframework.batch.item.mail中的类
This MailErrorHandler implementation simply rethrows the exception it receives.
DefaultMailErrorHandler() - 类 的构造器org.springframework.batch.item.mail.DefaultMailErrorHandler
 
DefaultPropertyEditorRegistrar - 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() - 类 的构造器org.springframework.batch.support.DefaultPropertyEditorRegistrar
 
DefaultRecordSeparatorPolicy - 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() - 类 的构造器org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Default constructor.
DefaultRecordSeparatorPolicy(String) - 类 的构造器org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character as parameter.
DefaultRecordSeparatorPolicy(String, String) - 类 的构造器org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character and continuation marker as parameters.
DefaultResultCompletionPolicy - org.springframework.batch.repeat.policy中的类
Very simple CompletionPolicy that bases its decision on the result of a batch operation.
DefaultResultCompletionPolicy() - 类 的构造器org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
 
DefaultStateTransitionComparator - org.springframework.batch.core.job.flow.support中的类
Sorts by decreasing specificity of pattern, based on just counting wildcards (with * taking precedence over ?).
DefaultStateTransitionComparator() - 类 的构造器org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
DefaultStepExecutionAggregator - org.springframework.batch.core.partition.support中的类
Convenience class for aggregating a set of StepExecution instances into a single result.
DefaultStepExecutionAggregator() - 类 的构造器org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
 
delegate(ResourceAwareItemReaderItemStream<? extends T>) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
Establishes the delegate to use for reading the resources provided.
delegate(ResourceAwareItemWriterItemStream<? super T>) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Delegate used for actual writing of the output.
delegate(ItemReader<T>) - 类 中的方法org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
The item reader to use as a delegate.
delegate(ItemStreamReader<T>) - 类 中的方法org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
The item stream reader to use as a delegate.
delegates(List<? extends ItemProcessor<?, ?>>) - 类 中的方法org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
Establishes the ItemProcessor delegates that will work on the item to be processed.
delegates(List<ItemWriter<? super T>>) - 类 中的方法org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
The list of item writers to use as delegates.
DelegateStep - org.springframework.batch.integration.step中的类
Provides a wrapper for an existing Step, delegating execution to it, but serving all other operations locally.
DelegateStep() - 类 的构造器org.springframework.batch.integration.step.DelegateStep
 
delete - 类 中的变量org.springframework.batch.item.KeyValueItemWriter
 
delete(boolean) - 类 中的方法org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Indicates if the items being passed to the writer are to be saved or removed from the data store.
delete(boolean) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Indicates if the items being passed to the writer are to be saved or removed from the data store.
delete(boolean) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
Boolean flag indicating whether the writer should save or delete the item at write time.
DELETE - org.springframework.batch.sample.domain.trade.CustomerOperation
 
delimited() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
delimited() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
DelimitedBuilder(FlatFileItemReaderBuilder<T>) - 类 的构造器org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
 
DelimitedBuilder(FlatFileItemWriterBuilder<T>) - 类 的构造器org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
 
DelimitedLineAggregator<T> - org.springframework.batch.item.file.transform中的类
A LineAggregator implementation that converts an object into a delimited list of strings.
DelimitedLineAggregator() - 类 的构造器org.springframework.batch.item.file.transform.DelimitedLineAggregator
 
DelimitedLineTokenizer - org.springframework.batch.item.file.transform中的类
A LineTokenizer implementation that splits the input String on a configurable delimiter.
DelimitedLineTokenizer() - 类 的构造器org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Create a new instance of the DelimitedLineTokenizer class for the common case where the delimiter is a comma.
DelimitedLineTokenizer(String) - 类 的构造器org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Create a new instance of the DelimitedLineTokenizer class.
delimiter(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Define the delimiter for the file.
delimiter(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
Define the delimiter for the file.
DELIMITER_COMMA - 类 中的静态变量org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a comma delimiter.
DELIMITER_TAB - 类 中的静态变量org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a tab delimiter.
DERBY - org.springframework.batch.support.DatabaseType
 
DerbyPagingQueryProvider - org.springframework.batch.item.database.support中的类
Derby implementation of a PagingQueryProvider using standard SQL:2003 windowing functions.
DerbyPagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
DESCENDING - org.springframework.batch.item.database.Order
 
deserialize(InputStream) - 类 中的方法org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
Deserializes an execution context from the provided InputStream.
deserialize(InputStream) - 类 中的方法org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
deserialize(InputStream) - 类 中的方法org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
Deserializes the supplied input stream into a new execution context.
destroy() - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Unregister all the Job instances that were registered by this post processor.
destroy() - 类 中的方法org.springframework.batch.sample.common.StagingItemReader
 
destroy() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
destroy() - 类 中的方法org.springframework.batch.test.DataSourceInitializer
 
detectStreamInReader() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
DirectPoller<S> - 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) - 类 的构造器org.springframework.batch.poller.DirectPoller
 
DISCOUNT_AMOUNT_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
DISCOUNT_PERC_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
distanceLimit(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configures the maximum tolerance between the actual spelling of a field's name and the property's name.
doAfterWrite(List<O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Call the listener's after write method.
doAggregate(Object[]) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineAggregator
 
doAggregate(Object[]) - 类 中的方法org.springframework.batch.item.file.transform.ExtractorLineAggregator
Aggregate provided fields into single String.
doAggregate(Object[]) - 类 中的方法org.springframework.batch.item.file.transform.FormatterLineAggregator
 
doAggregation(Collection<FlowExecution>, FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.SplitState
 
doAggregation(Collection<FlowExecution>, FlowExecutor) - 类 中的方法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) - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doCheckpoint() - 类 中的方法org.springframework.batch.jsr.item.CheckpointSupport
Used to provide a Serializable representing the current state of the batch artifact.
doCheckpoint() - 类 中的方法org.springframework.batch.jsr.item.ItemReaderAdapter
 
doCheckpoint() - 类 中的方法org.springframework.batch.jsr.item.ItemWriterAdapter
 
doCleanupAfterCompletion(Object) - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doClose() - 类 中的方法org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Close the cursor and database connection.
doClose() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
Close the cursor and hibernate session.
doClose() - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.json.JsonItemReader
 
doClose() - 类 中的方法org.springframework.batch.item.ldif.LdifReader
 
doClose() - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
 
doClose() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
doClose() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
doClose() - 类 中的方法org.springframework.batch.jsr.item.CheckpointSupport
Used to close the underlying batch artifact
doClose() - 类 中的方法org.springframework.batch.jsr.item.ItemReaderAdapter
 
doClose() - 类 中的方法org.springframework.batch.jsr.item.ItemWriterAdapter
 
doCommit(DefaultTransactionStatus) - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doExecute(JobExecution) - 类 中的方法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) - 类 中的方法org.springframework.batch.core.job.flow.FlowJob
 
doExecute(JobExecution) - 类 中的方法org.springframework.batch.core.job.SimpleJob
Handler of steps sequentially as provided, checking each one for success before moving to the next.
doExecute(JobExecution) - 类 中的方法org.springframework.batch.core.jsr.job.flow.JsrFlowJob
 
doExecute(StepExecution) - 类 中的方法org.springframework.batch.core.job.flow.FlowStep
Delegate to the flow provided for the execution of the step.
doExecute(StepExecution) - 类 中的方法org.springframework.batch.core.jsr.step.DecisionStep
 
doExecute(StepExecution) - 类 中的方法org.springframework.batch.core.jsr.step.PartitionStep
Delegate execution to the PartitionHandler provided.
doExecute(StepExecution) - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
Delegate execution to the PartitionHandler provided.
doExecute(StepExecution) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to execute business logic.
doExecute(StepExecution) - 类 中的方法org.springframework.batch.core.step.job.JobStep
Execute the job provided by delegating to the JobLauncher to prevent duplicate executions.
doExecute(StepExecution) - 类 中的方法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) - 类 中的方法org.springframework.batch.integration.step.DelegateStep
 
doExecutionRegistration(StepExecution) - 类 中的方法org.springframework.batch.core.jsr.step.BatchletStep
 
doExecutionRegistration(StepExecution) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Registers the StepExecution for property resolution via StepScope
doExecutionRelease() - 类 中的方法org.springframework.batch.core.step.AbstractStep
Releases the most recent StepExecution
doGetTransaction() - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doHandle(StepExecution, Set<StepExecution>) - 类 中的方法org.springframework.batch.core.partition.support.AbstractPartitionHandler
Executes the specified StepExecution instances and returns an updated view of them.
doHandle(StepExecution, Set<StepExecution>) - 类 中的方法org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
doInChunkContext(RepeatContext, ChunkContext) - 类 中的方法org.springframework.batch.core.scope.context.StepContextRepeatCallback
Do the work required for this chunk of the step.
doInIteration(RepeatContext) - 类 中的方法org.springframework.batch.core.scope.context.StepContextRepeatCallback
Manage the StepContext lifecycle.
doInIteration(RepeatContext) - 类 中的方法org.springframework.batch.repeat.callback.NestedRepeatCallback
Simply calls template.execute(callback).
doInIteration(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.RepeatCallback
Implementations return true if they can continue processing - e.g. there is a data source that is not yet exhausted.
doInJobScope(JobExecution, Callable<T>) - 类 中的静态方法org.springframework.batch.test.JobScopeTestUtils
 
doInStepScope(StepExecution, Callable<T>) - 类 中的静态方法org.springframework.batch.test.StepScopeTestUtils
 
doJumpToPage(int) - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
 
doJumpToPage(int) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
 
doJumpToPage(int) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
 
doJumpToPage(int) - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
DONE - 类 中的静态变量org.springframework.batch.sample.common.StagingItemWriter
 
doOnWriteError(Exception, List<O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Call listener's writerError method.
doOpen() - 类 中的方法org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Execute the statement to open the cursor.
doOpen() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
Open hibernate session and create a forward-only cursor for the query.
doOpen() - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.json.JsonItemReader
 
doOpen() - 类 中的方法org.springframework.batch.item.ldif.LdifReader
 
doOpen() - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
 
doOpen() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Open resources necessary to start reading input.
doOpen() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
doOpen(Serializable) - 类 中的方法org.springframework.batch.jsr.item.CheckpointSupport
Used to open a batch artifact with previously saved checkpoint information.
doOpen(Serializable) - 类 中的方法org.springframework.batch.jsr.item.ItemReaderAdapter
 
doOpen(Serializable) - 类 中的方法org.springframework.batch.jsr.item.ItemWriterAdapter
 
doPageRead() - 类 中的方法org.springframework.batch.item.data.AbstractPaginatedDataItemReader
Method this ItemStreamReader delegates to for the actual work of reading a page.
doPageRead() - 类 中的方法org.springframework.batch.item.data.MongoItemReader
 
doPageRead() - 类 中的方法org.springframework.batch.item.data.Neo4jItemReader
 
doPageRead() - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
Performs the actual reading of a page via the repository.
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.InlineFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParser
Create a bean definition for a FlowJob.
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.JobRepositoryParser
Parse and create a bean definition for a JobRepositoryFactoryBean .
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.TopLevelFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
 
doPersist(StepContribution, Chunk<O>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Implements writing and all related listener calls
doProcess(I) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
doProvide(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Implements reading as well as any related listener calls required.
doRead() - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
Surrounds the read call with listener callbacks.
doRead() - 类 中的方法org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
doRead() - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
 
doRead() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Read next row and map it to item, verify cursor position if AbstractCursorItemReader.setVerifyCursorPosition(boolean) is true.
doRead() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
 
doRead() - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
 
doRead() - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
 
doRead() - 类 中的方法org.springframework.batch.item.json.JsonItemReader
 
doRead() - 类 中的方法org.springframework.batch.item.ldif.LdifReader
 
doRead() - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
 
doRead() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Read next item from input.
doRead() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
Move to next fragment and map it to item.
doReadPage() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
 
doReadPage() - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
 
doReadPage() - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
 
doReadPage() - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
doRollback(DefaultTransactionStatus) - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doStronglyTypedLogging(Object) - 类 中的方法org.springframework.batch.sample.common.LogAdvice
 
doTokenize(String) - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
doTokenize(String) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doTokenize(String) - 类 中的方法org.springframework.batch.item.file.transform.FixedLengthTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doTokenize(String) - 类 中的方法org.springframework.batch.item.file.transform.RegexLineTokenizer
 
doTransform(I) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Implements processing and all related listener calls.
DOUBLE - org.springframework.batch.core.JobParameter.ParameterType
 
doUpdate(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
doWrite(List<? extends T>) - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
Performs the actual write to the store via the template.
doWrite(List<? extends T>) - 类 中的方法org.springframework.batch.item.data.Neo4jItemWriter
Performs the actual write using the template.
doWrite(List<? extends T>) - 类 中的方法org.springframework.batch.item.data.RepositoryItemWriter
Performs the actual write to the repository.
doWrite(List<? extends T>) - 类 中的方法org.springframework.batch.item.file.FlatFileItemWriter
 
doWrite(List<? extends T>) - 类 中的方法org.springframework.batch.item.json.JsonFileItemWriter
 
doWrite(List<? extends T>) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Write out a string of items followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
doWrite(List<O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Surrounds the actual write call with listener callbacks.
doWrite(EntityManager, List<? extends T>) - 类 中的方法org.springframework.batch.item.database.JpaItemWriter
Do perform the actual write operation.
doWrite(SessionFactory, List<? extends T>) - 类 中的方法org.springframework.batch.item.database.HibernateItemWriter
Do perform the actual write operation using Hibernate's API.
doWrite(HibernateOperations, List<? extends T>) - 类 中的方法org.springframework.batch.item.database.HibernateItemWriter
已过时。
As of 2.2 in favor of using Hibernate's session management APIs directly
driverSupportsAbsolute(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Indicates if the JDBC driver supports setting the absolute row on the ResultSet.
driverSupportsAbsolute(boolean) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates if the JDBC driver supports setting the absolute row on the ResultSet.
DummyItemWriter - org.springframework.batch.sample.support中的类
 
DummyItemWriter() - 类 的构造器org.springframework.batch.sample.support.DummyItemWriter
 
DuplicateJobException - org.springframework.batch.core.configuration中的异常错误
Checked exception that indicates a name clash when registering Job instances.
DuplicateJobException(String) - 异常错误 的构造器org.springframework.batch.core.configuration.DuplicateJobException
Create an exception with the given message.
DuplicateJobException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.configuration.DuplicateJobException
 
DynamicMethodInvocationException - org.springframework.batch.item.adapter中的异常错误
Indicates an error has been encountered while trying to dynamically invoke a method e.g. using MethodInvoker.
DynamicMethodInvocationException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.adapter.DynamicMethodInvocationException
 
DynamicMethodInvocationException(Throwable) - 异常错误 的构造器org.springframework.batch.item.adapter.DynamicMethodInvocationException
 

E

ELSE_KEY - 类 中的静态变量org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
EMBEDDED - 类 中的静态变量org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
System property key that switches the runner to "embedded" mode (returning immediately from the main method).
EnableBatchIntegration - org.springframework.batch.integration.config.annotation中的注释类型
Enable Spring Batch Integration features and provide a base configuration for setting up remote chunking or partitioning infrastructure beans.
EnableBatchProcessing - org.springframework.batch.core.configuration.annotation中的注释类型
Enable Spring Batch features and provide a base configuration for setting up batch jobs in an @Configuration class, roughly equivalent to using the <batch:*> XML namespace.
encoding(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure the encoding used by the reader to read the input source.
encoding(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Encoding used for output.
encoding(String) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Encoding used for output.
encoding(String) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Encoding for the file.
end() - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
A synonym for FlowBuilder.build() which callers might find useful.
end() - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
end(String) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the end of the flow with the status provided.
END_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
endCounter - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
endDocument(XMLEventWriter) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Writes the EndDocument tag manually.
EndState - org.springframework.batch.core.job.flow.support.state中的类
State implementation for ending a job if it is in progress and continuing if just starting.
EndState(FlowExecutionStatus, String) - 类 的构造器org.springframework.batch.core.job.flow.support.state.EndState
 
EndState(FlowExecutionStatus, String, String) - 类 的构造器org.springframework.batch.core.job.flow.support.state.EndState
 
EndState(FlowExecutionStatus, String, String, boolean) - 类 的构造器org.springframework.batch.core.job.flow.support.state.EndState
 
enhance(Job) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
 
enhance(Step) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
enhanceCommonStep(StepBuilderHelper<?>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
enhanceTaskletStepBuilder(AbstractTaskletStepBuilder<?>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
Entity - org.springframework.batch.core中的类
Batch Domain Entity class.
Entity() - 类 的构造器org.springframework.batch.core.Entity
 
Entity(Long) - 类 的构造器org.springframework.batch.core.Entity
 
entityClass(Class) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
 
entityManagerFactory(EntityManagerFactory) - 类 中的方法org.springframework.batch.item.database.builder.JpaItemWriterBuilder
The JPA EntityManagerFactory to obtain an entity manager from.
entityManagerFactory(EntityManagerFactory) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The EntityManagerFactory to be used for executing the configured JpaPagingItemReaderBuilder.queryString.
entrySet() - 类 中的方法org.springframework.batch.item.ExecutionContext
Returns the entry set containing the contents of this context.
ENVIRONMENT - 类 中的静态变量org.springframework.batch.support.SystemPropertyInitializer
Name of system property used by default.
equals(Object) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
equals(Object) - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
equals(Object) - 类 中的方法org.springframework.batch.core.Entity
Attempt to establish identity based on id if both exist.
equals(Object) - 类 中的方法org.springframework.batch.core.ExitStatus
Compare the fields one by one.
equals(Object) - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
Check the equality of the statuses.
equals(Object) - 类 中的方法org.springframework.batch.core.JobParameter
 
equals(Object) - 类 中的方法org.springframework.batch.core.JobParameters
 
equals(Object) - 类 中的方法org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
equals(Object) - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Extend the base class method to include the job execution itself as a key (i.e. two contexts are only equal if their job executions are the same).
equals(Object) - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Extend the base class method to include the step execution itself as a key (i.e. two contexts are only equal if their step executions are the same).
equals(Object) - 类 中的方法org.springframework.batch.core.StepContribution
 
equals(Object) - 类 中的方法org.springframework.batch.core.StepExecution
 
equals(Object) - 类 中的方法org.springframework.batch.core.test.football.Game
 
equals(Object) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
equals(Object) - 类 中的方法org.springframework.batch.item.ExecutionContext
 
equals(Object) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
equals(Object) - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.person.Child
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
equals(Object) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
equals(Object) - 类 中的方法org.springframework.batch.support.SimpleMethodInvoker
 
ERROR - org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Key for Classifier signalling that the throwable should be logged at error level.
ExceptionClassifierSkipPolicy - org.springframework.batch.core.step.skip中的类
A SkipPolicy that depends on an exception classifier to make its decision, and then delegates to the classifier result.
ExceptionClassifierSkipPolicy() - 类 的构造器org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
 
ExceptionElementParser - org.springframework.batch.core.configuration.xml中的类
 
ExceptionElementParser() - 类 的构造器org.springframework.batch.core.configuration.xml.ExceptionElementParser
 
exceptionHandler(ExceptionHandler) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the exception handler to use in the case of tasklet failures.
exceptionHandler(ExceptionHandler) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
ExceptionHandler - org.springframework.batch.repeat.exception中的接口
Handler to allow strategies for re-throwing exceptions.
ExceptionThrowingItemReaderProxy<T> - org.springframework.batch.sample.support中的类
Hacked ItemReader that throws exception on a given record number (useful for testing restart).
ExceptionThrowingItemReaderProxy() - 类 的构造器org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
execute(JobExecution) - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
execute(JobExecution) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Run the specified job, handling all listener and repository calls, and delegating the actual processing to AbstractJob.doExecute(JobExecution).
execute(JobExecution) - 接口 中的方法org.springframework.batch.core.Job
Run the JobExecution and update the meta information like status and statistics as necessary.
execute(Job, JobExecution) - 类 中的方法org.springframework.batch.core.scope.context.JobScopeManager
 
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
 
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Execute the provided Callable and return its RepeatStatus.
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
Delegate execution to the target object and translate the return value to an ExitStatus by invoking a method in the delegate POJO.
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Execute system command and map its exit code to ExitStatus using SystemProcessExitCodeMapper.
execute(StepContribution, ChunkContext) - 接口 中的方法org.springframework.batch.core.step.tasklet.Tasklet
Given the current context in the form of a step contribution, do whatever is necessary to process this unit inside a transaction.
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.core.test.timeout.SleepingTasklet
 
execute(StepContribution, ChunkContext) - 类 中的方法org.springframework.batch.sample.jsr352.JsrSampleTasklet
 
execute(StepExecution) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Template method for step execution logic - calls abstract methods for resource initialization ( AbstractStep.open(ExecutionContext)), execution logic (AbstractStep.doExecute(StepExecution)) and resource closing ( AbstractStep.close(ExecutionContext)).
execute(StepExecution) - 接口 中的方法org.springframework.batch.core.Step
Process the step and assign progress and status meta information to the StepExecution provided.
execute(Step, StepExecution) - 类 中的方法org.springframework.batch.core.scope.context.StepScopeManager
 
execute(RetryCallback<T, E>) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, Collection<RetryState>) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RecoveryCallback<T>) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RecoveryCallback<T>, Collection<RetryState>) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RecoveryCallback<T>, RetryState) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RetryState) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
executeAfterInterceptors(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Convenience method to execute after interceptors on a callback result.
executeInternal(JobExecutionContext) - 类 中的方法org.springframework.batch.sample.quartz.JobLauncherDetails
 
executeStep(Step) - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
 
executeStep(Step) - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
EXECUTING - 类 中的静态变量org.springframework.batch.core.ExitStatus
Convenient constant value representing continuable state where processing is still taking place, so no further action is required.
ExecutionContext - org.springframework.batch.item中的类
Object representing a context for an ItemStream.
ExecutionContext() - 类 的构造器org.springframework.batch.item.ExecutionContext
Default constructor.
ExecutionContext(Map<String, Object>) - 类 的构造器org.springframework.batch.item.ExecutionContext
Initializes a new execution context with the contents of another map.
ExecutionContext(ExecutionContext) - 类 的构造器org.springframework.batch.item.ExecutionContext
Initializes a new ExecutionContext with the contents of another ExecutionContext.
ExecutionContextDao - org.springframework.batch.core.repository.dao中的接口
DAO interface for persisting and retrieving ExecutionContexts.
ExecutionContextPromotionListener - org.springframework.batch.core.listener中的类
This class can be used to automatically promote items from the StepExecutionContext to the JobExecutionContext at the end of a step.
ExecutionContextPromotionListener() - 类 的构造器org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
ExecutionContextSerializer - org.springframework.batch.core.repository中的接口
A composite interface that combines both serialization and deserialization of an execution context into a single implementation.
ExecutionContextTestUtils - org.springframework.batch.test中的类
Convenience class for accessing ExecutionContext values from job and step executions.
ExecutionContextTestUtils() - 类 的构造器org.springframework.batch.test.ExecutionContextTestUtils
 
ExecutionContextUserSupport - org.springframework.batch.item.util中的类
Facilitates assigning names to objects persisting data in ExecutionContext and generating keys for ExecutionContext based on the name.
ExecutionContextUserSupport() - 类 的构造器org.springframework.batch.item.util.ExecutionContextUserSupport
 
ExecutionContextUserSupport(String) - 类 的构造器org.springframework.batch.item.util.ExecutionContextUserSupport
 
exit(int) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Delegate to the exiter to (possibly) exit the VM gracefully.
exit(int) - 类 中的方法org.springframework.batch.core.launch.support.JvmSystemExiter
Delegate call to System.exit() with the argument provided.
exit(int) - 接口 中的方法org.springframework.batch.core.launch.support.SystemExiter
Terminate the currently running Java Virtual Machine.
EXIT_CODE_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
ExitCodeMapper - org.springframework.batch.core.launch.support中的接口
This interface should be implemented when an environment calling the batch framework has specific requirements regarding the operating system process return status.
exitStatus - 类 中的变量org.springframework.batch.core.job.flow.JobFlowExecutor
 
ExitStatus - org.springframework.batch.core中的类
Value object used to carry information about the status of a job or step execution.
ExitStatus(String) - 类 的构造器org.springframework.batch.core.ExitStatus
 
ExitStatus(String, String) - 类 的构造器org.springframework.batch.core.ExitStatus
 
expect() - 类 中的方法org.springframework.batch.repeat.support.ResultHolderResultQueue
Tell the queue to expect one more result.
expect() - 类 中的方法org.springframework.batch.repeat.support.ThrottleLimitResultQueue
Tell the queue to expect one more result.
ExtendedConnectionDataSourceProxy - org.springframework.batch.item.database中的类
Implementation of SmartDataSource that is capable of keeping a single JDBC Connection which is NOT closed after each use even if Connection.close() is called.
ExtendedConnectionDataSourceProxy() - 类 的构造器org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
No arg constructor for use when configured using JavaBean style.
ExtendedConnectionDataSourceProxy(DataSource) - 类 的构造器org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Constructor that takes as a parameter with the DataSource to be wrapped.
extract(ChunkResponse, boolean) - 类 中的方法org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 
extract(LineItem) - 类 中的方法org.springframework.batch.sample.domain.order.internal.extractor.LineItemFieldExtractor
 
extract(Order) - 类 中的方法org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
 
extract(Order) - 类 中的方法org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
 
extract(Order) - 类 中的方法org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
 
extract(Order) - 类 中的方法org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
 
extract(Order) - 类 中的方法org.springframework.batch.sample.domain.order.internal.extractor.HeaderFieldExtractor
 
extract(T) - 类 中的方法org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
extract(T) - 接口 中的方法org.springframework.batch.item.file.transform.FieldExtractor
 
extract(T) - 类 中的方法org.springframework.batch.item.file.transform.PassThroughFieldExtractor
Get an array of fields as close as possible to the input.
ExtractorLineAggregator<T> - org.springframework.batch.item.file.transform中的类
An abstract LineAggregator implementation that utilizes a FieldExtractor to convert the incoming object to an array of its parts.
ExtractorLineAggregator() - 类 的构造器org.springframework.batch.item.file.transform.ExtractorLineAggregator
 
extractTableAlias() - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 

F

fail() - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the end of the flow with an error condition.
FAIL_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
FAILED - org.springframework.batch.core.BatchStatus
 
FAILED - 类 中的静态变量org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing with an error.
FAILED - 类 中的静态变量org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
FatalStepExecutionException - org.springframework.batch.core.step中的异常错误
 
FatalStepExecutionException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.FatalStepExecutionException
 
faultTolerant() - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
faultTolerant() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
FaultTolerantChunkProcessor<I,​O> - 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) - 类 的构造器org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
FaultTolerantChunkProvider<I> - 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) - 类 的构造器org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
FaultTolerantStepBuilder<I,​O> - org.springframework.batch.core.step.builder中的类
A step builder for fully fault tolerant chunk-oriented item processing steps.
FaultTolerantStepBuilder(SimpleStepBuilder<I, O>) - 类 的构造器org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepFactoryBean<T,​S> - org.springframework.batch.core.step.factory中的类
Factory bean for step that provides options for configuring skip behavior.
FaultTolerantStepFactoryBean() - 类 的构造器org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
fetchSize(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The number of items to be returned with each round trip to the database.
fetchSize(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Fetch size used internally by Hibernate to limit amount of data fetched from database per round trip.
fetchSize(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
A hint to the driver as to how many rows to return with each fetch.
fetchSize(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
A hint to the underlying RDBMS as to how many records to return with each fetch.
fetchSize(int) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
A hint to the driver as to how many rows to return with each fetch.
fieldExtractor(FieldExtractor<T>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
Set the FieldExtractor to use to extract fields from each item.
fieldExtractor(FieldExtractor<T>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the FieldExtractor to use to extract fields from each item.
FieldExtractor<T> - org.springframework.batch.item.file.transform中的接口
This class will convert an object to an array of its parts.
fields(String) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
JSON defining the fields to be returned from the matching documents by MongoDB.
FieldSet - org.springframework.batch.item.file.transform中的接口
Interface used by flat file input sources to encapsulate concerns of converting an array of Strings to Java native types.
fieldSetFactory(FieldSetFactory) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
A factory for creating the resulting FieldSet.
fieldSetFactory(FieldSetFactory) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
A factory for creating the resulting FieldSet.
FieldSetFactory - org.springframework.batch.item.file.transform中的接口
Factory interface for creating FieldSet instances.
fieldSetMapper(FieldSetMapper<T>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A FieldSetMapper implementation to be used.
FieldSetMapper<T> - org.springframework.batch.item.file.mapping中的接口
Interface that is used to map data obtained from a FieldSet into an object.
FileUtils - org.springframework.batch.item.util中的类
Utility methods for files used in batch processing.
findAllReachableElements(String, Map<String, Set<String>>, Set<String>) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
Find all of the elements reachable from the startElement.
findAutowiredAnnotation(AccessibleObject) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
 
findAutowiringMetadata(Class<?>) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
 
findBatchStatus(FlowExecutionStatus) - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
findByCreditGreaterThan(BigDecimal, Pageable) - 接口 中的方法org.springframework.batch.sample.data.CustomerCreditRepository
 
findJobExecutions(JobInstance) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findJobExecutions(JobInstance) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
Return all JobExecutions for given JobInstance, sorted backwards by creation order (so the first element is the most recent).
findJobExecutions(JobInstance) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
findJobInstancesByJobName(String, int, int) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
findJobInstancesByName(String, int, int) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
findJobInstancesByName(String, int, int) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
findMatchingMethod() - 类 中的方法org.springframework.batch.item.adapter.HippyMethodInvoker
 
findMethod(Class<?>) - 类 中的方法org.springframework.batch.support.AnnotationMethodResolver
Find a single Method on the given Class that contains the annotation type for which this resolver is searching.
findMethod(Class<?>) - 接口 中的方法org.springframework.batch.support.MethodResolver
Find a single Method on the given Class that matches this resolver's criteria.
findMethod(Class, Class<? extends Annotation>) - 类 中的静态方法org.springframework.batch.support.ReflectionUtils
Returns a Set of Method instances that are annotated with the annotation provided.
findMethod(Object) - 类 中的方法org.springframework.batch.support.AnnotationMethodResolver
Find a single Method on the Class of the given candidate object that contains the annotation type for which this resolver is searching.
findMethod(Object) - 接口 中的方法org.springframework.batch.support.MethodResolver
Find a single Method on the provided Object that matches this resolver's criteria.
findRunningJobExecutions(String) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Retrieve running job executions.
findRunningJobExecutions(String) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
findRunningJobExecutions(String) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findRunningJobExecutions(String) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
 
findRunningJobExecutions(String) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
FINISHED - org.springframework.batch.repeat.RepeatStatus
Indicates that processing is finished (either successful or unsuccessful)
FIRST_NAME_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
FIXED_AMOUNT - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
FIXED_AMOUNT - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
fixedLength() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
FixedLengthBuilder(FlatFileItemReaderBuilder<T>) - 类 的构造器org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
 
FixedLengthTokenizer - org.springframework.batch.item.file.transform中的类
Tokenizer used to process data obtained from files with fixed-length format.
FixedLengthTokenizer() - 类 的构造器org.springframework.batch.item.file.transform.FixedLengthTokenizer
 
FlatFileCustomerCreditDao - org.springframework.batch.sample.domain.trade.internal中的类
Writes customer's credit information in a file.
FlatFileCustomerCreditDao() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
FlatFileFooterCallback - org.springframework.batch.item.file中的接口
Callback interface for writing a footer to a file.
FlatFileFormatException - 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) - 异常错误 的构造器org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message.
FlatFileFormatException(String, String) - 异常错误 的构造器org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message.
FlatFileFormatException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message and another exception.
FlatFileHeaderCallback - org.springframework.batch.item.file中的接口
Callback interface for writing a header to a file.
FlatFileItemReader<T> - org.springframework.batch.item.file中的类
Restartable ItemReader that reads lines from input FlatFileItemReader.setResource(Resource).
FlatFileItemReader() - 类 的构造器org.springframework.batch.item.file.FlatFileItemReader
 
FlatFileItemReaderBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder implementation for the FlatFileItemReader.
FlatFileItemReaderBuilder() - 类 的构造器org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
 
FlatFileItemReaderBuilder.DelimitedBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder for constructing a DelimitedLineTokenizer
FlatFileItemReaderBuilder.FixedLengthBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder for constructing a FixedLengthTokenizer
FlatFileItemWriter<T> - org.springframework.batch.item.file中的类
This class is an item writer that writes data to a file or stream.
FlatFileItemWriter() - 类 的构造器org.springframework.batch.item.file.FlatFileItemWriter
 
FlatFileItemWriterBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder implementation for the FlatFileItemWriter
FlatFileItemWriterBuilder() - 类 的构造器org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
 
FlatFileItemWriterBuilder.DelimitedBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder for constructing a DelimitedLineAggregator
FlatFileItemWriterBuilder.FormattedBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder for constructing a FormatterLineAggregator.
FlatFileParseException - org.springframework.batch.item.file中的异常错误
Exception thrown when errors are encountered parsing flat files.
FlatFileParseException(String, String) - 异常错误 的构造器org.springframework.batch.item.file.FlatFileParseException
 
FlatFileParseException(String, String, int) - 异常错误 的构造器org.springframework.batch.item.file.FlatFileParseException
 
FlatFileParseException(String, Throwable, String, int) - 异常错误 的构造器org.springframework.batch.item.file.FlatFileParseException
 
flow - 类 中的变量org.springframework.batch.core.job.flow.FlowJob
 
flow() - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
 
flow(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowJobBuilder
Provide a single flow to execute as the job.
flow(Flow) - 类 中的方法org.springframework.batch.core.step.builder.FlowStepBuilder
Provide a flow to execute during the step.
flow(Flow) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Create a new step builder that will execute a flow.
flow(Flow) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
flow(Step) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
Flow - org.springframework.batch.core.job.flow中的接口
 
FLOW_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
FlowBuilder<Q> - 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) - 类 的构造器org.springframework.batch.core.job.builder.FlowBuilder
 
FlowBuilder.SplitBuilder<Q> - org.springframework.batch.core.job.builder中的类
A builder for building a split state.
FlowBuilder.TransitionBuilder<Q> - org.springframework.batch.core.job.builder中的类
A builder for transitions within a flow.
FlowBuilder.UnterminatedFlowBuilder<Q> - org.springframework.batch.core.job.builder中的类
A builder for continuing a flow from a decision state.
FlowBuilderException - org.springframework.batch.core.job.builder中的异常错误
 
FlowBuilderException(Exception) - 异常错误 的构造器org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String) - 异常错误 的构造器org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String, Exception) - 异常错误 的构造器org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowElementParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <flow/> elements inside a job.
FlowElementParser() - 类 的构造器org.springframework.batch.core.configuration.xml.FlowElementParser
 
FlowExecution - org.springframework.batch.core.job.flow中的类
 
FlowExecution(String, FlowExecutionStatus) - 类 的构造器org.springframework.batch.core.job.flow.FlowExecution
 
FlowExecutionAggregator - org.springframework.batch.core.job.flow.support.state中的接口
Strategy interface for aggregating FlowExecution instances into a single exit status.
FlowExecutionException - org.springframework.batch.core.job.flow中的异常错误
 
FlowExecutionException(String) - 异常错误 的构造器org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionStatus - org.springframework.batch.core.job.flow中的类
Represents the status of FlowExecution.
FlowExecutionStatus(String) - 类 的构造器org.springframework.batch.core.job.flow.FlowExecutionStatus
 
FlowExecutor - org.springframework.batch.core.job.flow中的接口
Context and execution strategy for FlowJob to allow it to delegate its execution step by step.
FlowHolder - org.springframework.batch.core.job.flow中的接口
Convenient interface for components that contain nested flows.
FlowJob - org.springframework.batch.core.job.flow中的类
Implementation of the Job interface that allows for complex flows of steps, rather than requiring sequential execution.
FlowJob() - 类 的构造器org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with null name and no flow (invalid state).
FlowJob(String) - 类 的构造器org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with provided name and no flow (invalid state).
FlowJobBuilder - org.springframework.batch.core.job.builder中的类
A job builder for FlowJob instances.
FlowJobBuilder(JobBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.job.builder.FlowJobBuilder
Create a new builder initialized with any properties in the parent.
FlowParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parses flows as defined in JSR-352.
FlowParser(String, String) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
FlowState - org.springframework.batch.core.job.flow.support.state中的类
State that delegates to a Flow
FlowState(Flow, String) - 类 的构造器org.springframework.batch.core.job.flow.support.state.FlowState
 
FlowStep - org.springframework.batch.core.job.flow中的类
A Step implementation that delegates to a Flow.
FlowStep() - 类 的构造器org.springframework.batch.core.job.flow.FlowStep
Default constructor convenient for configuration purposes.
FlowStep(Flow) - 类 的构造器org.springframework.batch.core.job.flow.FlowStep
Constructor for a FlowStep that sets the flow and of the step explicitly.
FlowStepBuilder - org.springframework.batch.core.step.builder中的类
A step builder for FlowStep instances.
FlowStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.FlowStepBuilder
Create a new builder initialized with any properties in the parent.
flush() - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
FlushFailedException - org.springframework.batch.support.transaction中的异常错误
Unchecked exception indicating that an error has occurred while trying to flush a buffer.
FlushFailedException(String) - 异常错误 的构造器org.springframework.batch.support.transaction.FlushFailedException
Create a new FlushFailedException based on a message.
FlushFailedException(String, Throwable) - 异常错误 的构造器org.springframework.batch.support.transaction.FlushFailedException
Create a new FlushFailedException based on a message and another exception.
FootballExceptionHandler - org.springframework.batch.sample.domain.football.internal中的类
 
FootballExceptionHandler() - 类 的构造器org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
 
footerCallback(FlatFileFooterCallback) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
A callback for footer processing
footerCallback(FlatFileFooterCallback) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
A callback for footer processing.
footerCallback(StaxWriterCallback) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
A StaxWriterCallback to provide any footer elements
FooterFieldExtractor - org.springframework.batch.sample.domain.order.internal.extractor中的类
 
FooterFieldExtractor() - 类 的构造器org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
 
ForceRollbackForWriteSkipException - 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) - 异常错误 的构造器org.springframework.batch.core.step.item.ForceRollbackForWriteSkipException
 
forceSync(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
A flag indicating that changes should be force-synced to disk on flush.
forceSync(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
A flag indicating that changes should be force-synced to disk on flush.
forceSync(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Flag to indicate that changes should be force-synced to disk on flush.
format(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the format string used to aggregate items
formatted() - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
FormattedBuilder(FlatFileItemWriterBuilder<T>) - 类 的构造器org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
 
FormatterLineAggregator<T> - org.springframework.batch.item.file.transform中的类
A LineAggregator implementation which produces a String by aggregating the provided item via the Formatter syntax.
FormatterLineAggregator() - 类 的构造器org.springframework.batch.item.file.transform.FormatterLineAggregator
 
FragmentEventReader - org.springframework.batch.item.xml.stax中的接口
Interface for event readers which support treating XML fragments as standalone XML documents by wrapping the fragments with StartDocument and EndDocument events.
from(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Start again from a subflow that was already registered.
from(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Start again from a decision that was already registered.
from(Step) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Go back to a previously registered step and start a new path.
fromClause(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL FROM clause for a db specific PagingQueryProvider.
fromCode(char) - 枚举 中的静态方法org.springframework.batch.sample.domain.trade.CustomerOperation
 
fromMetaData(DataSource) - 枚举 中的静态方法org.springframework.batch.support.DatabaseType
Convenience method that pulls a database product name from the DataSource's metadata.
fromProductName(String) - 枚举 中的静态方法org.springframework.batch.support.DatabaseType
Static method to obtain a DatabaseType from the provided product name.
fromPropertyName(String) - 枚举 中的静态方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - 枚举 中的静态方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - 枚举 中的静态方法org.springframework.batch.core.listener.JobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - 枚举 中的静态方法org.springframework.batch.core.listener.StepListenerMetaData
Return the relevant meta data for the provided property name.
function() - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates the stored procedure is a function
FunctionItemProcessor<I,​O> - org.springframework.batch.item.function中的类
An ItemProcessor implementation that delegates to a Function
FunctionItemProcessor(Function<I, O>) - 类 的构造器org.springframework.batch.item.function.FunctionItemProcessor
 

G

Game - org.springframework.batch.core.test.football中的类
 
Game - org.springframework.batch.sample.domain.football中的类
 
Game() - 类 的构造器org.springframework.batch.core.test.football.Game
 
Game() - 类 的构造器org.springframework.batch.sample.domain.football.Game
 
GameFieldSetMapper - org.springframework.batch.sample.domain.football.internal中的类
 
GameFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.football.internal.GameFieldSetMapper
 
GemfireItemWriter<K,​V> - org.springframework.batch.item.data中的类
An ItemWriter that stores items in GemFire
GemfireItemWriter() - 类 的构造器org.springframework.batch.item.data.GemfireItemWriter
 
GemfireItemWriterBuilder<K,​V> - org.springframework.batch.item.data.builder中的类
A builder implementation for the GemfireItemWriter
GemfireItemWriterBuilder() - 类 的构造器org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
 
generateFirstPageQuery(int) - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
Generate the query that will provide the first page, limited by the page size.
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Method generating the query string to be used for retrieving the first page.
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.H2PagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
generateFirstPageQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
generateGroupedTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
generateJumpToItemQuery(int, int) - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
Generate the query that will provide the jump to item query.
generateJumpToItemQuery(int, int) - 类 中的方法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) - 类 中的方法org.springframework.batch.item.database.support.H2PagingQueryProvider
 
generateJumpToItemQuery(int, int) - 类 中的方法org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 
generateJumpToItemQuery(int, int) - 类 中的方法org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 
generateJumpToItemQuery(int, int) - 类 中的方法org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
generateJumpToItemQuery(int, int) - 类 中的方法org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
generateJumpToItemQuery(int, int) - 类 中的方法org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
generateJumpToItemQuery(int, int) - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
generateKey(JobParameters) - 类 中的方法org.springframework.batch.core.DefaultJobKeyGenerator
Generates the job key to be used based on the JobParameters instance provided.
generateKey(T) - 接口 中的方法org.springframework.batch.core.JobKeyGenerator
Method to generate the unique key used to identify a job instance.
generateLimitCypherQuery() - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
 
generateLimitGroupedSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause
generateLimitJumpToQuery(AbstractSqlPagingQueryProvider, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause
generateLimitSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause
generateRemainingPagesQuery(int) - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
Generate the query that will provide the first page, limited by the page size.
generateRemainingPagesQuery(int) - 类 中的方法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) - 类 中的方法org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.H2PagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
generateRemainingPagesQuery(int) - 类 中的方法org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a ROW_NUM condition
generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, String, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a ROW_NUM condition
generateRowNumSqlQueryWithNesting(AbstractSqlPagingQueryProvider, String, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
generateRowNumSqlQueryWithNesting(AbstractSqlPagingQueryProvider, String, String, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
generateTopJumpToQuery(AbstractSqlPagingQueryProvider, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
generateTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - 类 中的静态方法org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
GeneratingTradeItemReader - org.springframework.batch.sample.domain.trade.internal中的类
Generates configurable number of Trade items.
GeneratingTradeItemReader() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
GeneratingTradeResettingListener - org.springframework.batch.sample.loop中的类
This listener resets the count of its GeneratingTradeItemReader after the step.
GeneratingTradeResettingListener() - 类 的构造器org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
GenericApplicationContextFactory - org.springframework.batch.core.configuration.support中的类
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
GenericApplicationContextFactory(Object...) - 类 的构造器org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
Create an application context factory for the resource specified.
get(String) - 类 中的方法org.springframework.batch.core.configuration.annotation.JobBuilderFactory
Creates a job builder and initializes its job repository.
get(String) - 类 中的方法org.springframework.batch.core.configuration.annotation.StepBuilderFactory
Creates a step builder and initializes its job repository and transaction manager.
get(String) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilderFactory
Creates a RemoteChunkingMasterStepBuilder and initializes its job repository and transaction manager.
get(String) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
Creates a RemotePartitioningMasterStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
get(String) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
Creates a RemotePartitioningWorkerStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
get(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Getter for the value represented by the provided key.
get(String, ObjectFactory<?>) - 类 中的方法org.springframework.batch.core.scope.JobScope
 
get(String, ObjectFactory<?>) - 类 中的方法org.springframework.batch.core.scope.StepScope
 
getActualCount() - 异常错误 中的方法org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getActualLength() - 异常错误 中的方法org.springframework.batch.item.file.transform.IncorrectLineLengthException
Retrieves the actual length that was recorded for this exception.
getAddress() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getAddress() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
getAddressee() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
getAddrLine1() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
getAddrLine2() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - 类 中的方法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() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getAge() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
getAggregator() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getAllFailureExceptions() - 类 中的方法org.springframework.batch.core.JobExecution
Return all failure causing exceptions for this JobExecution, including step executions.
getAllowStartIfComplete() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getAnnotation() - 枚举 中的方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getAnnotation() - 枚举 中的方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getAnnotation() - 枚举 中的方法org.springframework.batch.core.listener.JobListenerMetaData
 
getAnnotation() - 接口 中的方法org.springframework.batch.core.listener.ListenerMetaData
 
getAnnotation() - 枚举 中的方法org.springframework.batch.core.listener.StepListenerMetaData
 
getApplicationContext() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
 
getArguments() - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Return arguments.
getArtifactProperties(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the batch Properties for the provided artifact name.
getAsText() - 类 中的方法org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
getAttempts() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getAttempts() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getAttempts() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getAttempts() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getAttribute(String) - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
getAttribute(String, String, ConfigurableListableBeanFactory) - 类 中的静态方法org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getBatchStatus() - 枚举 中的方法org.springframework.batch.core.BatchStatus
Converts the current status to the JSR-352 equivalent
getBatchStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getBatchStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getBatchStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getBatchStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getBatchStatusFromEndTransitionName(String) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass() - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getBeanClass() - 类 中的方法org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getBeanClass() - 类 中的方法org.springframework.batch.core.configuration.xml.StepListenerParser
 
getBeanClass(Element) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass(Element) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParser
 
getBeanClass(Element) - 类 中的方法org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
getBeanClass(Element) - 类 中的方法org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
getBeanClass(Element) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
getBeanClass(Element) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
 
getBeanClassName(Element) - 类 中的方法org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
getBeanFactoryPostProcessorClasses() - 类 中的方法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() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getBillingAddress() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getBirthYear() - 类 中的方法org.springframework.batch.core.test.football.Player
 
getBirthYear() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
getBufferSize() - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Convenience method for clients to determine if there is any unflushed data.
getChildren() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
getChunkCompletionPolicy() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getChunkMonitor() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
getChunkOperations() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the chunk operations to make them available in subclasses.
getChunkSize() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getCity() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
getClobTypeToUse() - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getCloseSuppressingConnectionProxy(Connection) - 类 中的方法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() - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
 
getCode() - 枚举 中的方法org.springframework.batch.item.file.transform.Alignment
 
getCode() - 枚举 中的方法org.springframework.batch.sample.domain.trade.CustomerOperation
 
getCommitCount() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the current number of commits for this execution
getCommitInterval() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getCompanyName() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
getCompletes() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getCompletes() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getCompletes() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getCompletes() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getCompletionPolicy() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getCompositeListener() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
getConfigurations() - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
getConfigurations() - 接口 中的方法org.springframework.batch.sample.launch.JobLoader
 
getConfigurer(Collection<BatchConfigurer>) - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
getConnection() - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getConnection(String, String) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getContext() - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator.BaseContextHolder
 
getContext() - 类 中的静态方法org.springframework.batch.core.scope.context.JobSynchronizationManager
Getter for the current context if there is one, otherwise returns null.
getContext() - 类 中的静态方法org.springframework.batch.core.scope.context.StepSynchronizationManager
Getter for the current context if there is one, otherwise returns null.
getContext() - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Getter for the current context if there is one, otherwise returns null.
getContext() - 类 中的静态方法org.springframework.batch.repeat.support.RepeatSynchronizationManager
Getter for the current context.
getConversationId() - 类 中的方法org.springframework.batch.core.scope.JobScope
 
getConversationId() - 类 中的方法org.springframework.batch.core.scope.StepScope
 
getCount() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextCounter
 
getCount(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
getCounter() - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
getCounter() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
getCounter() - 类 中的方法org.springframework.batch.sample.support.RetrySampleItemWriter
 
getCountry() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
getCreateTime() - 类 中的方法org.springframework.batch.core.JobExecution
 
getCreateTime() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getCredit() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
getCredit() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getCurrent() - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
getCurrentItemCount() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
getCurrentResource() - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
Getter for the current resource.
getCustomer() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
getCustomer() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getCustomer() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
getCustomerByName(String) - 接口 中的方法org.springframework.batch.sample.domain.trade.CustomerDao
 
getCustomerByName(String) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
getCustomerName() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getData() - 类 中的方法org.springframework.batch.sample.domain.person.PersonService
 
getDataSource() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Public getter for the data source.
getDate() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
getDate(String) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the Date represented by the provided key.
getDate(String, Date) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the Date represented by the provided key.
getDebit() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
getDebutYear() - 类 中的方法org.springframework.batch.core.test.football.Player
 
getDebutYear() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
getDefaultExitStatusForFailure(Throwable, JobExecution) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Default mapping from throwable to ExitStatus.
getDefaultExitStatusForFailure(Throwable, JobExecution) - 类 中的方法org.springframework.batch.core.jsr.job.flow.JsrFlowJob
Default mapping from throwable to ExitStatus.
getDefaultListenerClass() - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getDefaultListenerClass() - 类 中的方法org.springframework.batch.core.listener.JobListenerFactoryBean
 
getDefaultListenerClass() - 类 中的方法org.springframework.batch.core.listener.StepListenerFactoryBean
 
getDescription() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getDiscountAmount() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getDiscountPerc() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getDouble(String) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getDouble(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key.
getDouble(String, double) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the Double represented by the provided key.
getDouble(String, double) - 类 中的方法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() - 类 中的方法org.springframework.batch.sample.domain.mail.User
 
getEncoding() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get used encoding.
getEndTime() - 类 中的方法org.springframework.batch.core.JobExecution
 
getEndTime() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getEndTime() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getEndTime() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the time that this execution ended
getEntityManager() - 类 中的方法org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
Getter for EntityManager
getErrorMessage() - 类 中的静态方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Retrieve the error message set by an instance of CommandLineJobRunner as it exits.
getErrors() - 类 中的静态方法org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Public getter for the startup errors encountered during parent context creation.
getErrors() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
getErrors() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
Public accessor for the errors property.
getException() - 类 中的方法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() - 类 中的方法org.springframework.batch.core.step.item.SkipWrapper
Public getter for the exception.
getExceptionHandler() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to access the exception handler that was injected by user.
getExceptionHandler() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ExceptionHandler.
getExceptionTranslator() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Creates a default SQLErrorCodeSQLExceptionTranslator for the specified DataSource if none is set.
getExecutionContext() - 类 中的方法org.springframework.batch.core.JobExecution
Returns the ExecutionContext for this execution.
getExecutionContext() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the ExecutionContext for this execution
getExecutionContext(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
getExecutionContext(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
getExecutionContextDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getExecutionContextKey(String) - 类 中的方法org.springframework.batch.item.ItemStreamSupport
 
getExecutionId() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getExecutionId() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getExecutions(long) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getExitCode() - 类 中的方法org.springframework.batch.core.ExitStatus
Getter for the exit code (defaults to blank).
getExitDescription() - 类 中的方法org.springframework.batch.core.ExitStatus
Getter for the exit description (defaults to blank)
getExitStatus() - 类 中的方法org.springframework.batch.core.JobExecution
 
getExitStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getExitStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getExitStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getExitStatus() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getExitStatus() - 类 中的方法org.springframework.batch.core.StepContribution
Public getter for the status.
getExitStatus() - 类 中的方法org.springframework.batch.core.StepExecution
 
getExitStatus(int) - 类 中的方法org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
getExitStatus(int) - 类 中的方法org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
getExitStatus(int) - 接口 中的方法org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
 
getExpectedCount() - 异常错误 中的方法org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getExpectedLength() - 异常错误 中的方法org.springframework.batch.item.file.transform.IncorrectLineLengthException
Retrieves the expected length that was recorded for this exception.
getFailedMessages() - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
getFailureExceptions() - 类 中的方法org.springframework.batch.core.JobExecution
 
getFailureExceptions() - 类 中的方法org.springframework.batch.core.StepExecution
 
getFatalExceptionAwareProxy(SkipPolicy) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Wrap a SkipPolicy and make it consistent with known fatal exceptions.
getFaultTolerantStepBuilder(String) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getFaultTolerantStepBuilder(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
getFieldCount() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
getFieldCount() - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Return the number of fields in this 'FieldSet'.
getFilterCount() - 类 中的方法org.springframework.batch.core.StepContribution
Public getter for the filter counter.
getFilterCount() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the current number of items filtered out of this execution
getFilterCount(Chunk<I>, Chunk<O>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getFilterCount(Chunk<I>, Chunk<O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to calculate the filter count.
getFirstName() - 类 中的方法org.springframework.batch.core.test.football.Player
 
getFirstName() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
getFirstName() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
getFirstName() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
getFlows() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
getFlows() - 接口 中的方法org.springframework.batch.core.job.flow.FlowHolder
 
getFlows() - 类 中的方法org.springframework.batch.core.job.flow.support.state.FlowState
 
getFlows() - 类 中的方法org.springframework.batch.core.job.flow.support.state.SplitState
 
getFooter() - 类 中的静态方法org.springframework.batch.sample.domain.multiline.AggregateItem
 
getForwardOnlyCursor(int, Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Get a cursor over all of the results, with the forward-only flag set.
getFromClause() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getGridSize() - 类 中的方法org.springframework.batch.core.partition.support.AbstractPartitionHandler
Returns the number of step executions.
getGridSize() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getGroupClause() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
The getter for the group by clause
getGroupName(BeanDefinition, Job) - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Determine a group name for the job to be registered.
getHandlingPrice() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getHeader() - 类 中的静态方法org.springframework.batch.sample.domain.multiline.AggregateItem
 
getId() - 类 中的方法org.springframework.batch.core.Entity
 
getId() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
 
getId() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
 
getId() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getId() - 类 中的方法org.springframework.batch.core.test.football.Player
 
getId() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getId() - 类 中的方法org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
getId() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getId() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
getId() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getId() - 类 中的方法org.springframework.batch.sample.domain.mail.User
 
getId() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
getId() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
getId() - 类 中的方法org.springframework.batch.sample.validation.domain.Person
 
getIncrementer(String, String) - 接口 中的方法org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Return the DataFieldMaxValueIncrementer for the provided database type.
getIncrementer(String, String) - 类 中的方法org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
getInput() - 异常错误 中的方法org.springframework.batch.item.file.FlatFileParseException
 
getInput() - 异常错误 中的方法org.springframework.batch.item.file.NonTransientFlatFileException
 
getInput() - 异常错误 中的方法org.springframework.batch.item.file.transform.FlatFileFormatException
Retrieve the input that caused this exception.
getInput() - 异常错误 中的方法org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getInputChannelAttributeName() - 类 中的方法org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
getInstance() - 类 中的静态方法org.springframework.batch.core.jsr.launch.JsrJobOperator.BaseContextHolder
 
getInstanceId() - 类 中的方法org.springframework.batch.core.JobInstance
 
getInstanceId() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getInt(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key.
getInt(String, int) - 类 中的方法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() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getInterceptions() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getInterceptions() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getInterceptions() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getIsin() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
getItem() - 类 中的方法org.springframework.batch.core.step.item.SkipWrapper
Public getter for the item.
getItem() - 类 中的方法org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
getItem() - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItem
Accessor for the wrapped item.
getItemId() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getItemListeners() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getItemProcessor() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemProcessor for subclasses to use
getItemReader() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemReader for subclasses to use.
getItems() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
getItems() - 类 中的方法org.springframework.batch.integration.chunk.ChunkRequest
 
getItemWriter() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemWriter for subclasses to use
getJdbcTemplate() - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getJob() - 类 中的方法org.springframework.batch.integration.launch.JobLaunchRequest
 
getJob() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
 
getJob() - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
 
getJob(String) - 接口 中的方法org.springframework.batch.core.configuration.JobLocator
Locates a Job at runtime.
getJob(String) - 类 中的方法org.springframework.batch.core.configuration.support.MapJobRegistry
 
getJobConfiguration(String) - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
getJobConfiguration(String) - 接口 中的方法org.springframework.batch.sample.launch.JobLoader
 
getJobConfigurationName() - 类 中的方法org.springframework.batch.core.JobExecution
 
getJobExecution() - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
 
getJobExecution() - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
getJobExecution() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
The current JobExecution that is active in this context.
getJobExecution() - 类 中的方法org.springframework.batch.core.StepExecution
Accessor for the execution context information of the enclosing job.
getJobExecution(long) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobExecution(Long) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Retrieve a JobExecution by its id.
getJobExecution(Long) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobExecution(Long) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobExecution(Long) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
 
getJobExecution(Long) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getJobExecution(TestContext) - 类 中的方法org.springframework.batch.test.JobScopeTestExecutionListener
Discover a JobExecution as a field in the test case or create one if none is available.
getJobExecutionContext() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
 
getJobExecutionContext() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
 
getJobExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getJobExecutionId() - 类 中的方法org.springframework.batch.core.StepExecution
Accessor for the job execution id.
getJobExecutionId() - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequest
 
getJobExecutionListeners() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobExecutions(JobInstance) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobExecutions(JobInstance) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Retrieve job executions by their job instance.
getJobExecutions(JobInstance) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobExplorer() - 接口 中的方法org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobExplorer() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobId() - 类 中的方法org.springframework.batch.core.JobExecution
Convenience getter for for the id of the enclosing job.
getJobId() - 类 中的方法org.springframework.batch.integration.chunk.ChunkRequest
 
getJobId() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
getJobInstance() - 类 中的方法org.springframework.batch.core.JobExecution
 
getJobInstance(long) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobInstance(Long) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
 
getJobInstance(Long) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstance(Long) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(Long) - 接口 中的方法org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the job instance with the provided identifier.
getJobInstance(Long) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstance(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
The job table is queried for any jobs that match the given identifier, adding them to a list via the RowMapper callback.
getJobInstance(String, JobParameters) - 接口 中的方法org.springframework.batch.core.repository.dao.JobInstanceDao
Find the job instance that matches the given name and parameters.
getJobInstance(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstance(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the JobInstance for the provided JobExecution.
getJobInstance(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstanceCount(String) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Query the repository for the number of unique JobInstances associated with the supplied job name.
getJobInstanceCount(String) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstanceCount(String) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobInstanceCount(String) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstanceCount(String) - 接口 中的方法org.springframework.batch.core.repository.dao.JobInstanceDao
Query the repository for the number of unique JobInstances associated with the supplied job name.
getJobInstanceCount(String) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstanceDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getJobInstances(String, int, int) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Fetch JobInstance values in descending order of creation (and therefore usually of first execution).
getJobInstances(String, int, int) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstances(String, int, int) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobInstances(String, int, int) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobInstances(String, int, int) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstances(String, int, int) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobLauncher() - 接口 中的方法org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobLauncher() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobLauncher() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
 
getJobLauncher() - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
 
getJobName() - 接口 中的方法org.springframework.batch.core.configuration.JobFactory
 
getJobName() - 类 中的方法org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Just return the name of instance passed in on initialization.
getJobName() - 类 中的方法org.springframework.batch.core.configuration.support.ReferenceJobFactory
Just return the name of instance passed in on initialization.
getJobName() - 类 中的方法org.springframework.batch.core.JobInstance
 
getJobName() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getJobName() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getJobName() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Convenient accessor for current job name identifier.
getJobName() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Convenient accessor for current job name identifier.
getJobNames() - 接口 中的方法org.springframework.batch.core.configuration.ListableJobLocator
Provides the currently registered job names.
getJobNames() - 类 中的方法org.springframework.batch.core.configuration.support.MapJobRegistry
Provides an unmodifiable view of the job names.
getJobNames() - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Query the repository for all unique JobInstance names (sorted alphabetically).
getJobNames() - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobNames() - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobNames() - 接口 中的方法org.springframework.batch.core.launch.JobOperator
List the available job names that can be launched with JobOperator.start(String, String).
getJobNames() - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobNames() - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobNames() - 接口 中的方法org.springframework.batch.core.repository.dao.JobInstanceDao
Retrieve the names of all job instances sorted alphabetically - i.e. jobs that have ever been executed.
getJobNames() - 类 中的方法org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobParameters() - 类 中的方法org.springframework.batch.core.JobExecution
 
getJobParameters() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
getJobParameters() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getJobParameters() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
 
getJobParameters() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
 
getJobParameters() - 类 中的方法org.springframework.batch.core.StepExecution
Convenience method to get the current job parameters.
getJobParameters() - 类 中的方法org.springframework.batch.integration.launch.JobLaunchRequest
 
getJobParameters(Long) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobParameters(Properties) - 类 中的方法org.springframework.batch.core.converter.DefaultJobParametersConverter
Check for suffix on keys and use those to decide how to convert the value.
getJobParameters(Properties) - 接口 中的方法org.springframework.batch.core.converter.JobParametersConverter
Get a new JobParameters instance.
getJobParameters(Properties) - 类 中的方法org.springframework.batch.core.jsr.JsrJobParametersConverter
 
getJobParameters(Properties) - 类 中的方法org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
getJobParameters(Job, StepExecution) - 类 中的方法org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
getJobParameters(Job, StepExecution) - 接口 中的方法org.springframework.batch.core.step.job.JobParametersExtractor
Extract job parameters from the step execution, for example from the execution context or other properties.
getJobParametersIncrementer() - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
getJobParametersIncrementer() - 类 中的方法org.springframework.batch.core.job.AbstractJob
 
getJobParametersIncrementer() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobParametersIncrementer() - 接口 中的方法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() - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
getJobParametersValidator() - 类 中的方法org.springframework.batch.core.job.AbstractJob
 
getJobParametersValidator() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobParametersValidator() - 接口 中的方法org.springframework.batch.core.Job
A validator for the job parameters of a JobExecution.
getJobProperties() - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the Job level properties.
getJobProperties() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
getJobRepository() - 接口 中的方法org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobRepository() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobRepository() - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
getJobRepository() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getJobRepository() - 类 中的方法org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to access the job repository.
getJobRepository() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobRepository() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
 
getJobRepository() - 类 中的方法org.springframework.batch.core.job.SimpleStepHandler
 
getJobRepository() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
getJobRepository() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
getJobRepository() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
getJobRepository() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getJobRepository() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
getJobRepository() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
 
getJobRepository() - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
 
getJobRestartProperties(Properties, JobExecution) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJsrRetryListeners() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
getKey(Object) - 接口 中的方法org.springframework.batch.core.step.item.KeyGenerator
 
getKey(Object[]) - 类 中的方法org.springframework.batch.item.jms.JmsMethodArgumentsKeyGenerator
If the message is a Message then returns the JMS message ID.
getKey(String) - 类 中的方法org.springframework.batch.item.util.ExecutionContextUserSupport
Prefix the argument with ExecutionContextUserSupport.getName() to create a unique key that can be safely used to identify data stored in ExecutionContext.
getLabel() - 枚举 中的方法org.springframework.batch.item.file.transform.Alignment
 
getLast_name() - 类 中的方法org.springframework.batch.sample.domain.person.Person
Intentionally non-standard method name for testing purposes
getLastJobExecution(String, JobParameters) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
 
getLastJobExecution(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastJobExecution(JobInstance) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getLastJobExecution(JobInstance) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
Find the last JobExecution to have been created for a given JobInstance.
getLastJobExecution(JobInstance) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getLastName() - 类 中的方法org.springframework.batch.core.test.football.Player
 
getLastName() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
getLastName() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
getLastStepExecution(JobInstance, String) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
 
getLastStepExecution(JobInstance, String) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastUpdated() - 类 中的方法org.springframework.batch.core.JobExecution
Get the date representing the last time this JobExecution was updated in the JobRepository.
getLastUpdated() - 类 中的方法org.springframework.batch.core.StepExecution
 
getLastUpdatedTime() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getLimit() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
getLineItems() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
getLineItems() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getLineNumber() - 异常错误 中的方法org.springframework.batch.item.file.FlatFileParseException
 
getLineNumber() - 异常错误 中的方法org.springframework.batch.item.file.NonTransientFlatFileException
 
getLinesWritten() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
getListener() - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
 
getListener() - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
getListener() - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
 
getListener(Object) - 类 中的静态方法org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to wrap any object and expose the appropriate JobExecutionListener interfaces.
getListener(Object) - 类 中的静态方法org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to wrap any object and expose the appropriate StepListener interfaces.
getListenerInterface() - 枚举 中的方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getListenerInterface() - 枚举 中的方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getListenerInterface() - 枚举 中的方法org.springframework.batch.core.listener.JobListenerMetaData
 
getListenerInterface() - 接口 中的方法org.springframework.batch.core.listener.ListenerMetaData
 
getListenerInterface() - 枚举 中的方法org.springframework.batch.core.listener.StepListenerMetaData
 
getListeners() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the StepListeners.
getLoginTimeout() - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getLogWriter() - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getLong(String) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getLong(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Long represented by the provided key.
getLong(String, long) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getLong(String, long) - 类 中的方法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() - 类 中的方法org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
getMax() - 类 中的方法org.springframework.batch.item.file.transform.Range
 
getMessage() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
getMetaDataFromPropertyName(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
 
getMetaDataFromPropertyName(String) - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataFromPropertyName(String) - 类 中的方法org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - 类 中的方法org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.configuration.xml.StepListenerParser
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataValues() - 类 中的方法org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMethodInvokerByAnnotation(Class<? extends Annotation>, Object) - 类 中的静态方法org.springframework.batch.support.MethodInvokerUtils
Create MethodInvoker for the method with the provided annotation on the provided object.
getMethodInvokerByAnnotation(Class<? extends Annotation>, Object, Class<?>...) - 类 中的静态方法org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker from the delegate based on the annotationType.
getMethodInvokerByName(Object, String, boolean, Class<?>...) - 类 中的静态方法org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker using the provided method name to search.
getMethodInvokerByName(String, Object, Class<?>...) - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMethodInvokerForInterface(Class<?>, String, Object, Class<?>...) - 类 中的静态方法org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker using the provided interface, and method name from that interface.
getMethodInvokerForSingleArgument(Object) - 类 中的静态方法org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker for the delegate from a single public method.
getMethodName() - 枚举 中的方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getMethodName() - 枚举 中的方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getMethodName() - 枚举 中的方法org.springframework.batch.core.listener.JobListenerMetaData
 
getMethodName() - 接口 中的方法org.springframework.batch.core.listener.ListenerMetaData
 
getMethodName() - 枚举 中的方法org.springframework.batch.core.listener.StepListenerMetaData
 
getMetric(StepExecution, Metric.MetricType) - 类 中的静态方法org.springframework.batch.test.JsrTestUtils
 
getMetrics() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getMetrics() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getMiddleName() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
getMin() - 类 中的方法org.springframework.batch.item.file.transform.Range
 
getMoo() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getMostRecentStepName() - 类 中的方法org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
getName() - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
Concatenates the group name and the delegate job name (joining with a ".").
getName() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getName() - 类 中的方法org.springframework.batch.core.job.AbstractJob
 
getName() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getName() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
 
getName() - 接口 中的方法org.springframework.batch.core.job.flow.Flow
 
getName() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecution
 
getName() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
 
getName() - 接口 中的方法org.springframework.batch.core.job.flow.State
The name of the state.
getName() - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
Get the name for this flow.
getName() - 类 中的方法org.springframework.batch.core.job.flow.support.state.AbstractState
 
getName() - 接口 中的方法org.springframework.batch.core.Job
 
getName() - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
 
getName() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
getName() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getName() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
getName() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public getter for the name of the step.
getName() - 接口 中的方法org.springframework.batch.core.Step
 
getName() - 类 中的方法org.springframework.batch.item.util.ExecutionContextUserSupport
 
getName() - 类 中的方法org.springframework.batch.sample.domain.mail.User
 
getName() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getName() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
getName() - 类 中的方法org.springframework.batch.sample.domain.person.Child
 
getName() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
getName() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
getName() - 类 中的方法org.springframework.batch.sample.validation.domain.Person
 
getNames() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
getNames() - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Accessor for the names of the fields.
getNext() - 类 中的方法org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the next State name.
getNext(JobParameters) - 接口 中的方法org.springframework.batch.core.JobParametersIncrementer
Increment the provided parameters.
getNext(JobParameters) - 类 中的方法org.springframework.batch.core.launch.support.RunIdIncrementer
Increment the run.id parameter (starting with 1).
getNextElements(ParserContext, String, BeanDefinition, Element) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getNextElements(ParserContext, String, BeanDefinition, Element) - 类 中的静态方法org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
getNextElements(ParserContext, BeanDefinition, Element) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getNextElements(ParserContext, BeanDefinition, Element) - 类 中的静态方法org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
getNextJobParameters(Job) - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Initializes the JobParameters based on the state of the Job.
getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Get the next completed result, possibly executing several callbacks until one finally finishes.
getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - 类 中的方法org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
getObject() - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
getObject() - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Create a Step from the configuration provided.
getObject() - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Create a Step from the configuration provided.
getObject() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Create a Step from the configuration provided.
getObject() - 类 中的方法org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
getObject() - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Builds a ChunkHandler from the ChunkProcessor extracted from the step provided.
getObject() - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Get a PagingQueryProvider instance using the provided properties and appropriate for the given database type.
getObjectType() - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
The type of object returned by this factory - an array of ApplicationContextFactory.
getObjectType() - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
The type of object to be returned from FactoryBean.getObject().
getObjectType() - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.listener.JobListenerFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.listener.StepListenerFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The type of object to be returned from AbstractJobRepositoryFactoryBean.getObject().
getObjectType() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
getObjectType() - 类 中的方法org.springframework.batch.core.step.StepLocatorStepFactoryBean
Tell clients that we are a factory for Step instances.
getObjectType() - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The type of object created by this factory.
getObjectType() - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Always returns PagingQueryProvider.
getOffset() - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
getOperation() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getOpponent() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getOpponent() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getOrder() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
getOrder() - 类 中的方法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 BeanFactoryPostProcessors
getOrder() - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
 
getOrderDate() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getOrderedQueryAlias() - 类 中的方法org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOrderedQueryAlias() - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOrderId() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getOutputState() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
 
getOverClause() - 类 中的方法org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOverClause() - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOverSubstituteClauseEnd() - 类 中的方法org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOverSubstituteClauseEnd() - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOverSubstituteClauseStart() - 类 中的方法org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOverSubstituteClauseStart() - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getPage() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
The current page number.
getPageSize() - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
The page size configured for this reader.
getParameterCount() - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
The number of parameters that are declared in the query
getParameterCount() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getParameters() - 类 中的方法org.springframework.batch.core.JobParameters
Get a map of all parameters, including string, long, and date.
getParameters(long) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getParameters(long) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Get the JobParameters as an easily readable String.
getParameters(long) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getParameterValues() - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
 
getParamTypes() - 枚举 中的方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getParamTypes() - 枚举 中的方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getParamTypes() - 枚举 中的方法org.springframework.batch.core.listener.JobListenerMetaData
 
getParamTypes() - 接口 中的方法org.springframework.batch.core.listener.ListenerMetaData
 
getParamTypes() - 枚举 中的方法org.springframework.batch.core.listener.StepListenerMetaData
 
getParamTypesString(Class<?>...) - 类 中的静态方法org.springframework.batch.support.MethodInvokerUtils
Create a String representation of the array of parameter types.
getParent() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
getParent() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
If batches are nested, then the inner batch will be created with the outer one as a parent.
getParentLogger() - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Added due to JDK 7 compatibility.
getPartitioner() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getPartitionHandler() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getPartitionHandler() - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
 
getPartitionHandler() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getPartitionNames(int) - 接口 中的方法org.springframework.batch.core.partition.support.PartitionNameProvider
 
getPartitionPlan() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
 
getPartitionProperties() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getPartitions() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getPartitionsOverride() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getPartitionStepNames() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
getPassingTd() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getPassingTd() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getPassingTd() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getPassingTd() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getPassingYards() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getPassingYards() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getPassingYards() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getPassingYards() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getPattern() - 类 中的方法org.springframework.batch.core.job.flow.support.StateTransition
 
getPaymentDesc() - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
getPaymentId() - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
getPerOunceRate() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
getPersistentUserData() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getPersistentUserData() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getPerUnitOunces() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getPhase() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
getPoo() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getPosition() - 类 中的方法org.springframework.batch.core.test.football.Player
 
getPosition() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
getPrice() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getPrice() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getPrice() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
getProcessor() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getProcessSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
Public getter for the process skip count.
getProcessSkipCount() - 类 中的方法org.springframework.batch.core.StepExecution
 
getProductName() - 枚举 中的方法org.springframework.batch.support.DatabaseType
 
getProperties() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getProperties() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getProperties() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
getProperties() - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Construct name-value pairs from the field names and string values.
getProperties(JobParameters) - 类 中的方法org.springframework.batch.core.converter.DefaultJobParametersConverter
Use the same suffixes to create properties (omitting the string suffix because it is the default).
getProperties(JobParameters) - 接口 中的方法org.springframework.batch.core.converter.JobParametersConverter
The inverse operation: get a Properties instance.
getProperties(JobParameters) - 类 中的方法org.springframework.batch.core.jsr.JsrJobParametersConverter
 
getProperties(JobParameters) - 类 中的方法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.
getProperty(String) - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
getProperty(String) - 接口 中的方法org.springframework.batch.sample.launch.JobLoader
 
getPropertyName() - 枚举 中的方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getPropertyName() - 枚举 中的方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getPropertyName() - 枚举 中的方法org.springframework.batch.core.listener.JobListenerMetaData
 
getPropertyName() - 接口 中的方法org.springframework.batch.core.listener.ListenerMetaData
 
getPropertyName() - 枚举 中的方法org.springframework.batch.core.listener.StepListenerMetaData
 
getPropertyValue(String, String, ConfigurableListableBeanFactory) - 类 中的静态方法org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getQuantity() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getQuantity() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getQuantity() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
getQuery(String) - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getReadCount() - 类 中的方法org.springframework.batch.core.StepContribution
Public access to the read counter.
getReadCount() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the current number of items read for this execution
getReader() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
 
getReader() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getReadSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
 
getReadSkipCount() - 类 中的方法org.springframework.batch.core.StepExecution
 
getReceivedCount() - 类 中的方法org.springframework.batch.sample.domain.person.PersonService
 
getReceivedMessages() - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
getReceptions() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getReceptions() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getReceptions() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getReceptions() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getReceptionYards() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getReceptionYards() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getReceptionYards() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getReceptionYards() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getRegistrationId() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
getRestartable() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getResult(XMLEventWriter) - 类 中的静态方法org.springframework.batch.item.xml.StaxUtils
 
getReturnedCount() - 类 中的方法org.springframework.batch.sample.domain.person.PersonService
 
getRollbackClassifier() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Convenience method to get an exception classifier based on the provided transaction attributes.
getRollbackCount() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the current number of rollbacks for this execution
getRootElementAttributes() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get attributes of the root element.
getRootTagName() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get the tag name of the root element.
getRootTagNamespace() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get the namespace of the root element.
getRootTagNamespacePrefix() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get the namespace prefix of the root element.
getRunningExecutions(String) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getRunningExecutions(String) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Get the id values of all the running JobExecutions with the given job name.
getRunningExecutions(String) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getRushes() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getRushes() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getRushes() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getRushes() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getRushYards() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getRushYards() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getRushYards() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getRushYards() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getSelectClause() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getSequence() - 类 中的方法org.springframework.batch.integration.chunk.ChunkRequest
 
getSequence() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
getSessionFactory() - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
 
getShipper() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
getShipperId() - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
getShipping() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getShippingAddress() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getShippingInfo() - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
getShippingPrice() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getShippingTypeId() - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
getSimpleStepBuilder(String) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getSimpleStepBuilder(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
getSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
 
getSkipCount() - 类 中的方法org.springframework.batch.core.StepExecution
 
getSkipLimit() - 异常错误 中的方法org.springframework.batch.core.step.skip.SkipLimitExceededException
 
getSkipListeners() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
getSkips() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
getSortKeyPlaceHolder(String) - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
Returns either a String to be used as the named placeholder for a sort key value (based on the column name) or a ?
getSortKeyPlaceHolder(String) - 类 中的方法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() - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
The sort keys.
getSortKeys() - 类 中的方法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() - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
The sort key (unique single column name) without alias.
getSortKeysWithoutAliases() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getSource(XMLEventReader) - 类 中的静态方法org.springframework.batch.item.xml.StaxUtils
 
getSplitTaskExecutorPropertyValue(BeanDefinitionRegistry) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
 
getSplitter() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getSql() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
 
getSql() - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
 
getSql() - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
 
getStartable(StepExecution, ExecutionContext) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
已过时。
getStartedCount() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
getStartedCount() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Public access to a counter for the number of operations attempted.
getStartLimit() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
getStartLimit() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getStartLimit() - 接口 中的方法org.springframework.batch.core.Step
 
getStartState() - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
getStartTime() - 类 中的方法org.springframework.batch.core.JobExecution
 
getStartTime() - 类 中的方法org.springframework.batch.core.jsr.JsrJobExecution
 
getStartTime() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getStartTime() - 类 中的方法org.springframework.batch.core.StepExecution
Gets the time this execution started
getState() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
getState() - 类 中的方法org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the State.
getState() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
getState(String) - 接口 中的方法org.springframework.batch.core.job.flow.Flow
Retrieve the State with the given name.
getState(String) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
Retrieve the State with the given name.
getStatefulSession() - 类 中的方法org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
getStatelessSession() - 类 中的方法org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
getStateMap() - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
getStates() - 接口 中的方法org.springframework.batch.core.job.flow.Flow
Convenient accessor for clients needing to explore the states of this flow.
getStates() - 类 中的方法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) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getStatus() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecution
 
getStatus() - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
 
getStatus() - 类 中的方法org.springframework.batch.core.JobExecution
 
getStatus() - 异常错误 中的方法org.springframework.batch.core.JobInterruptedException
The desired status of the surrounding execution after the interruption.
getStatus() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the current status of this step
getStep() - 类 中的方法org.springframework.batch.core.job.flow.support.state.StepState
 
getStep() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
getStep() - 类 中的方法org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
The step instance that will be executed in parallel by this handler.
getStep() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getStep() - 接口 中的方法org.springframework.batch.core.step.StepHolder
 
getStep(String) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Retrieve the step with the given name.
getStep(String) - 类 中的方法org.springframework.batch.core.job.flow.FlowJob
Retrieve the step with the given name.
getStep(String) - 类 中的方法org.springframework.batch.core.job.flow.support.state.StepState
 
getStep(String) - 类 中的方法org.springframework.batch.core.job.SimpleJob
 
getStep(String) - 类 中的方法org.springframework.batch.core.jsr.step.PartitionStep
 
getStep(String) - 接口 中的方法org.springframework.batch.core.step.StepLocator
 
getStep(String) - 类 中的方法org.springframework.batch.integration.partition.BeanFactoryStepLocator
Look up a bean with the provided name of type Step.
getStep(String, String) - 接口 中的方法org.springframework.batch.core.configuration.StepRegistry
Returns the Step of the specified job based on its name.
getStep(String, String) - 类 中的方法org.springframework.batch.core.configuration.support.MapStepRegistry
 
getStepArtifactProperties(String, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the batch Properties for the provided Step and artifact name.
getStepContext() - 类 中的方法org.springframework.batch.core.scope.context.ChunkContext
 
getStepContribution() - 类 中的方法org.springframework.batch.integration.chunk.ChunkRequest
 
getStepContribution() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
getStepContributions() - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
getStepContributions() - 接口 中的方法org.springframework.batch.integration.chunk.StepContributionSource
Get the currently available contributions and drain the source.
getStepExecution() - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
 
getStepExecution() - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
getStepExecution() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
The current StepExecution that is active in this context.
getStepExecution(Long, Long) - 接口 中的方法org.springframework.batch.core.explore.JobExplorer
Retrieve a StepExecution by its id and parent JobExecution id.
getStepExecution(Long, Long) - 类 中的方法org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getStepExecution(JobExecution, Long) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getStepExecution(JobExecution, Long) - 类 中的方法org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
getStepExecution(JobExecution, Long) - 接口 中的方法org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve a StepExecution from its id.
getStepExecution(TestContext) - 类 中的方法org.springframework.batch.test.StepScopeTestExecutionListener
Discover a StepExecution as a field in the test case or create one if none is available.
getStepExecutionAggergator() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getStepExecutionContext() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
 
getStepExecutionCount(JobInstance, String) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
 
getStepExecutionCount(JobInstance, String) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
getStepExecutionDao() - 类 中的方法org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getStepExecutionId() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getStepExecutionId() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getStepExecutionId() - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequest
 
getStepExecutionListeners() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getStepExecutions() - 类 中的方法org.springframework.batch.core.JobExecution
Accessor for the step executions.
getStepExecutions(long) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getStepExecutionSplitter() - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
 
getStepExecutionSummaries(long) - 接口 中的方法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) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getStepName() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getStepName() - 类 中的方法org.springframework.batch.core.jsr.JsrStepExecution
 
getStepName() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
 
getStepName() - 接口 中的方法org.springframework.batch.core.partition.StepExecutionSplitter
The name of the step configuration that will be executed remotely.
getStepName() - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
getStepName() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Convenient accessor for current step name identifier.
getStepName() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getStepName() - 类 中的方法org.springframework.batch.core.StepExecution
 
getStepName() - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequest
 
getStepNames() - 类 中的方法org.springframework.batch.core.job.AbstractJob
Retrieve the step names.
getStepNames() - 类 中的方法org.springframework.batch.core.job.flow.FlowJob
Retrieve the step names.
getStepNames() - 类 中的方法org.springframework.batch.core.job.flow.support.state.StepState
 
getStepNames() - 类 中的方法org.springframework.batch.core.job.SimpleJob
Convenience method for clients to inspect the steps for this job.
getStepNames() - 类 中的方法org.springframework.batch.core.jsr.step.PartitionStep
 
getStepNames() - 接口 中的方法org.springframework.batch.core.step.StepLocator
 
getStepNames() - 类 中的方法org.springframework.batch.integration.partition.BeanFactoryStepLocator
Look in the bean factory for all beans of type Step.
getStepOperations() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to access the step operations that were injected by user.
getStepOperations() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the step operations to make them available in subclasses.
getStepProperties(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the Step level properties for the provided Step name.
getStepRunner() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Convenient method for subclasses to grab a StepRunner for running steps by name.
getStepRunner() - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Convenient method for subclasses to grab a StepRunner for running steps by name.
getStepSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
 
getStreams() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getString(String) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the String represented by the provided key.
getString(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Typesafe Getter for the String represented by the provided key.
getString(String, String) - 类 中的方法org.springframework.batch.core.JobParameters
Typesafe Getter for the String represented by the provided key.
getString(String, String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Typesafe Getter for the String represented by the provided key with default value to return if key is not represented.
getStringCode() - 枚举 中的方法org.springframework.batch.item.file.transform.Alignment
 
getSubQueryAlias() - 类 中的方法org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
getSubQueryAlias() - 类 中的方法org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
getSubQueryAlias() - 类 中的方法org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getSubQueryAlias() - 类 中的方法org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
getSuffix(int) - 接口 中的方法org.springframework.batch.item.file.ResourceSuffixCreator
 
getSuffix(int) - 类 中的方法org.springframework.batch.item.file.SimpleResourceSuffixCreator
 
getSummary() - 类 中的方法org.springframework.batch.core.StepExecution
 
getSummary(long) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Summarise the JobExecution with the supplied id, giving details of status, start and end times etc.
getSummary(long) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
getSupportedIncrementerTypes() - 接口 中的方法org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Returns the list of supported database incrementer types
getSupportedIncrementerTypes() - 类 中的方法org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
getSystemProperties() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
getSystemProperties() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
getTablePrefix() - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getTargetNamePrefix() - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
 
getTargetNamePrefix() - 类 中的方法org.springframework.batch.core.scope.JobScope
 
getTargetNamePrefix() - 类 中的方法org.springframework.batch.core.scope.StepScope
 
getTargetType() - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
 
getTaskExecutor() - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getTaskExecutor() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getTaskExecutor() - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getTaskExecutor() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Make the TaskExecutor available to subclasses
getTasklet() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getTasklet() - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
retrieve the tasklet - helper method for JobOperator
getTeam() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getTeam() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getTemplate() - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
Get the MongoOperations to be used to save items to be written.
getThreads() - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getThrottleLimit() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getThrowables() - 接口 中的方法org.springframework.batch.repeat.support.RepeatInternalState
Returns a mutable collection of exceptions that have occurred in the current repeat context.
getThrowables() - 类 中的方法org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
getTitle() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
getTotalItems() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getTotalLines() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getTotalPrice() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
getTotalPrice() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
getTotalPrice() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
getTotalTd() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getTotalTd() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getTotalTd() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getTotalTd() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getTransactionAttribute() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getTransactionAttribute() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Getter for the TransactionAttribute for subclasses only.
getTransactionManager() - 接口 中的方法org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getTransactionManager() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getTransactionManager() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getTransactionManager() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The transaction manager used in this factory.
getTransactionManager() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getTransactionManager() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
getTransientUserData() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
getTransientUserData() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
getTransitionMap() - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
getType() - 类 中的方法org.springframework.batch.core.JobParameter
 
getType() - 类 中的方法org.springframework.batch.core.jsr.SimpleMetric
 
getUnclosedElements() - 类 中的方法org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
 
getUniqueJobParameters() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
 
getUniqueJobParameters() - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
 
getUserData() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
getValue() - 类 中的方法org.springframework.batch.core.JobParameter
 
getValue() - 类 中的方法org.springframework.batch.core.jsr.SimpleMetric
 
getValueFromJob(JobExecution, String) - 类 中的静态方法org.springframework.batch.test.ExecutionContextTestUtils
 
getValueFromStep(StepExecution, String) - 类 中的静态方法org.springframework.batch.test.ExecutionContextTestUtils
 
getValueFromStepInJob(JobExecution, String, String) - 类 中的静态方法org.springframework.batch.test.ExecutionContextTestUtils
 
getValues() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
getValues() - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
 
getVersion() - 类 中的方法org.springframework.batch.core.Entity
 
getVersion() - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get XML version.
getVersion() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
getWeek() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getWeek() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getWhereClause() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getWriteCount() - 类 中的方法org.springframework.batch.core.StepContribution
Public access to the write counter.
getWriteCount() - 类 中的方法org.springframework.batch.core.StepExecution
Returns the current number of items written for this execution
getWriter() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getWriteSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
 
getWriteSkipCount() - 类 中的方法org.springframework.batch.core.StepExecution
 
getWrittenItems() - 类 中的方法org.springframework.batch.item.support.ListItemWriter
 
getYear() - 类 中的方法org.springframework.batch.core.test.football.Game
 
getYear() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
getYear() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
getYear() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
getZipCode() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
gridSize(int) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
A hint to the PartitionStepBuilder.splitter(StepExecutionSplitter) about how many step executions are required.
gridSize(int) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
GroupAwareJob - org.springframework.batch.core.configuration.support中的类
A Job that can optionally prepend a group name to another job's name, to make it fit a naming convention for type or origin.
GroupAwareJob(String, Job) - 类 的构造器org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the given group name and delegate.
GroupAwareJob(Job) - 类 的构造器org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the delegate and no group name.
groupClause(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL GROUP BY clause for a db specific @PagingQueryProvider.
GsonJsonObjectMarshaller<T> - org.springframework.batch.item.json中的类
A json object marshaller that uses Google Gson to marshal an object into a json representation.
GsonJsonObjectMarshaller() - 类 的构造器org.springframework.batch.item.json.GsonJsonObjectMarshaller
 
GsonJsonObjectReader<T> - org.springframework.batch.item.json中的类
Implementation of JsonObjectReader based on Google Gson.
GsonJsonObjectReader(Class<? extends T>) - 类 的构造器org.springframework.batch.item.json.GsonJsonObjectReader
Create a new GsonJsonObjectReader instance.

H

H2 - org.springframework.batch.support.DatabaseType
 
H2PagingQueryProvider - org.springframework.batch.item.database.support中的类
H2 implementation of a PagingQueryProvider using database specific features.
H2PagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.H2PagingQueryProvider
 
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
handle(FlowExecutor) - 接口 中的方法org.springframework.batch.core.job.flow.State
Handle some business or processing logic and return a status that can be used to drive a flow to the next State.
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.AbstractState
 
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.DecisionState
 
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
Return the FlowExecutionStatus stored.
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.FlowState
 
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.SplitState
Execute the flows in parallel by passing them to the TaskExecutor and wait for all of them to finish before proceeding.
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.StepState
 
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
handle(FlowExecutor) - 类 中的方法org.springframework.batch.core.jsr.job.flow.support.state.JsrStepState
 
handle(StepExecutionSplitter, StepExecution) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
handle(StepExecutionSplitter, StepExecution) - 接口 中的方法org.springframework.batch.core.partition.PartitionHandler
Main entry point for PartitionHandler interface.
handle(StepExecutionSplitter, StepExecution) - 类 中的方法org.springframework.batch.core.partition.support.AbstractPartitionHandler
 
handle(StepExecutionSplitter, StepExecution) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Sends StepExecutionRequest objects to the request channel of the MessagingTemplate, and then receives the result back as a list of StepExecution on a reply channel.
handle(StepExecutionRequest) - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequestHandler
 
handle(MailMessage, Exception) - 类 中的方法org.springframework.batch.item.mail.DefaultMailErrorHandler
Wraps the input exception with a runtime MailException.
handle(MailMessage, Exception) - 接口 中的方法org.springframework.batch.item.mail.MailErrorHandler
This method will be called for each message that failed sending in the chunk.
handle(MailMessage, Exception) - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
handleChunk(ChunkRequest<S>) - 类 中的方法org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
handleChunk(ChunkRequest<T>) - 接口 中的方法org.springframework.batch.integration.chunk.ChunkHandler
Handle the chunk, processing all the items and returning a response summarising the result.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Check if the exception is going to be retried, and veto the handling if it is.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.exception.CompositeExceptionHandler
Iterate over the handlers delegating the call to each in turn.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.exception.DefaultExceptionHandler
Re-throw the throwable.
handleException(RepeatContext, Throwable) - 接口 中的方法org.springframework.batch.repeat.exception.ExceptionHandler
Deal with a Throwable during a batch - decide whether it should be re-thrown in the first place.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Classify the throwables and decide whether to rethrow based on the result.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Classify the throwables and decide whether to re-throw based on the result.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Rethrows only if the limit is breached for this context on the exception type specified.
handleException(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
 
handleLine(String) - 接口 中的方法org.springframework.batch.item.file.LineCallbackHandler
 
handleLine(String) - 类 中的方法org.springframework.batch.sample.support.HeaderCopyCallback
 
handleListenerException(Throwable) - 类 中的方法org.springframework.batch.container.jms.BatchMessageListenerContainer
Override base class to prevent exceptions from being swallowed.
handleListenersElement(Element, BeanDefinition, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.StepListenerParser
 
handleRecord(LdapAttributes) - 接口 中的方法org.springframework.batch.item.ldif.RecordCallbackHandler
Execute operations on the supplied record.
handleRequestMessage(Message<?>) - 类 中的方法org.springframework.batch.integration.launch.JobLaunchingGateway
Launches a Batch Job using the provided request Message.
handleStep(Step, JobExecution) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to delegate the handling of a specific step in the context of the current JobExecution.
handleStep(Step, JobExecution) - 类 中的方法org.springframework.batch.core.job.SimpleStepHandler
 
handleStep(Step, JobExecution) - 接口 中的方法org.springframework.batch.core.job.StepHandler
Handle a step and return the execution for it.
handleWarnings(Statement) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Throw a SQLWarningException if we're not ignoring warnings, else log the warnings (at debug level).
HANDLING_PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
hasAttribute(String) - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hasChunkElement() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
hashCode() - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
hashCode() - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
hashCode() - 类 中的方法org.springframework.batch.core.Entity
Use ID if it exists to establish hash code, otherwise fall back to Object.hashCode().
hashCode() - 类 中的方法org.springframework.batch.core.ExitStatus
Compatible with the equals implementation.
hashCode() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
 
hashCode() - 类 中的方法org.springframework.batch.core.JobParameter
 
hashCode() - 类 中的方法org.springframework.batch.core.JobParameters
 
hashCode() - 类 中的方法org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
hashCode() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Overrides the default behaviour to provide a hash code based only on the job execution.
hashCode() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Overrides the default behaviour to provide a hash code based only on the step execution.
hashCode() - 类 中的方法org.springframework.batch.core.StepContribution
 
hashCode() - 类 中的方法org.springframework.batch.core.StepExecution
 
hashCode() - 类 中的方法org.springframework.batch.core.test.football.Game
 
hashCode() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
hashCode() - 类 中的方法org.springframework.batch.item.ExecutionContext
 
hashCode() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
hashCode() - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.person.Child
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
hashCode() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
hashCode() - 类 中的方法org.springframework.batch.support.SimpleMethodInvoker
 
hasMaxValue() - 类 中的方法org.springframework.batch.item.file.transform.Range
 
hasNames() - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
hasNames() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
hasNames() - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Check if there are names defined for the fields.
hasNext() - 类 中的方法org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
hasNext() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
hasPartitionElement() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
hasTasklet() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
headerCallback(FlatFileHeaderCallback) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
A callback for header processing.
headerCallback(FlatFileHeaderCallback) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
A callback for header processing.
headerCallback(StaxWriterCallback) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
A StaxWriterCallback to provide any header elements
HeaderCopyCallback - org.springframework.batch.sample.support中的类
Designed to be registered with both FlatFileItemReader and FlatFileItemWriter and copy header line from input file to output file.
HeaderCopyCallback() - 类 的构造器org.springframework.batch.sample.support.HeaderCopyCallback
 
HeaderFieldExtractor - org.springframework.batch.sample.domain.order.internal.extractor中的类
 
HeaderFieldExtractor() - 类 的构造器org.springframework.batch.sample.domain.order.internal.extractor.HeaderFieldExtractor
 
HeaderFieldSetMapper - org.springframework.batch.sample.domain.order.internal.mapper中的类
 
HeaderFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
HibernateAwareCustomerCreditItemWriter - org.springframework.batch.sample.domain.trade.internal中的类
Delegates writing to a custom DAO and flushes + clears hibernate session to fulfill the ItemWriter contract.
HibernateAwareCustomerCreditItemWriter() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
HibernateCreditDao - org.springframework.batch.sample.domain.trade.internal中的类
 
HibernateCreditDao() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
HibernateCursorItemReader<T> - org.springframework.batch.item.database中的类
ItemStreamReader for reading database records built on top of Hibernate.
HibernateCursorItemReader() - 类 的构造器org.springframework.batch.item.database.HibernateCursorItemReader
 
HibernateCursorItemReaderBuilder<T> - org.springframework.batch.item.database.builder中的类
This is a builder for the HibernateCursorItemReader.
HibernateCursorItemReaderBuilder() - 类 的构造器org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
 
HibernateItemReaderHelper<T> - org.springframework.batch.item.database中的类
Internal shared state helper for hibernate readers managing sessions and queries.
HibernateItemReaderHelper() - 类 的构造器org.springframework.batch.item.database.HibernateItemReaderHelper
 
HibernateItemWriter<T> - org.springframework.batch.item.database中的类
ItemWriter that uses a Hibernate session to save or update entities that are not part of the current Hibernate session.
HibernateItemWriter() - 类 的构造器org.springframework.batch.item.database.HibernateItemWriter
 
HibernateItemWriterBuilder<T> - org.springframework.batch.item.database.builder中的类
A builder for the HibernateItemWriter
HibernateItemWriterBuilder() - 类 的构造器org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
 
HibernateNativeQueryProvider<E> - org.springframework.batch.item.database.orm中的类
This query provider creates Hibernate Querys from injected native SQL queries.
HibernateNativeQueryProvider() - 类 的构造器org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
HibernatePagingItemReader<T> - org.springframework.batch.item.database中的类
ItemReader for reading database records built on top of Hibernate and reading only up to a fixed number of items at a time.
HibernatePagingItemReader() - 类 的构造器org.springframework.batch.item.database.HibernatePagingItemReader
 
HibernatePagingItemReaderBuilder<T> - org.springframework.batch.item.database.builder中的类
A builder for the HibernatePagingItemReader.
HibernatePagingItemReaderBuilder() - 类 的构造器org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
 
HibernateQueryProvider<T> - org.springframework.batch.item.database.orm中的接口
Interface defining the functionality to be provided for generating queries for use with Hibernate ItemReaders or other custom built artifacts.
hint(String) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
JSON String telling MongoDB what index to use.
HippyMethodInvoker - org.springframework.batch.item.adapter中的类
A MethodInvoker that is a bit relaxed about its arguments.
HippyMethodInvoker() - 类 的构造器org.springframework.batch.item.adapter.HippyMethodInvoker
 
HSQL - org.springframework.batch.support.DatabaseType
 
HsqlPagingQueryProvider - org.springframework.batch.item.database.support中的类
HSQLDB implementation of a PagingQueryProvider using database specific features.
HsqlPagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 

I

ID_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
ID_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractStepParser
 
ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
ID_KEY - 类 中的静态变量org.springframework.batch.core.scope.JobScope
Context key for clients to use for conversation identifier.
ID_KEY - 类 中的静态变量org.springframework.batch.core.scope.StepScope
Context key for clients to use for conversation identifier.
ignoreItemStream(boolean) - 类 中的方法org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
Establishes the policy whether to call the open, close, or update methods for the item writer delegates associated with the CompositeItemWriter.
ignoreWarnings(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
 
ignoreWarnings(boolean) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates if SQL warnings should be ignored or if an exception should be thrown.
inboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
inboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
inboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
inboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
inboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.WorkerConfiguration
 
includedFields(Integer[]) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
A list of indices of the fields within a delimited file to be included
IncorrectLineLengthException - org.springframework.batch.item.file.transform中的异常错误
Exception indicating that the line size expected is different from what is expected.
IncorrectLineLengthException(int, int) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(int, int, String) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(String, int, int) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(String, int, int, String) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectTokenCountException - org.springframework.batch.item.file.transform中的异常错误
Exception indicating that an incorrect number of tokens have been found while parsing a file.
IncorrectTokenCountException(int, int) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(int, int, String) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(String, int, int) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(String, int, int, String) - 异常错误 的构造器org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
increaseCreditBy(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
increment() - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
increment() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextCounter
Increment by 1.
increment() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
Used by clients to increment the started count.
increment(int) - 类 中的方法org.springframework.batch.repeat.context.RepeatContextCounter
Increment the counter.
incrementCommitCount() - 类 中的方法org.springframework.batch.core.StepExecution
Increment the number of commits
incrementer - 类 中的变量org.springframework.batch.core.jsr.JsrJobParametersConverter
 
incrementer(JobParametersIncrementer) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
Add a job parameters incrementer.
incrementFilterCount(int) - 类 中的方法org.springframework.batch.core.StepContribution
Increment the counter for the number of items processed.
incrementOffset() - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
incrementProcessSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
 
incrementReadCount() - 类 中的方法org.springframework.batch.core.StepContribution
Increment the counter for the number of items read.
incrementReadSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
Increment the read skip count for this contribution
incrementReadSkipCount(int) - 类 中的方法org.springframework.batch.core.StepContribution
Increment the read skip count for this contribution
incrementRollbackCount() - 类 中的方法org.springframework.batch.core.StepExecution
On unsuccessful execution after a chunk has rolled back.
incrementVersion() - 类 中的方法org.springframework.batch.core.Entity
Increment the version number
incrementWriteCount(int) - 类 中的方法org.springframework.batch.core.StepContribution
Increment the counter for the number of items written.
incrementWriteSkipCount() - 类 中的方法org.springframework.batch.core.StepContribution
Increment the write skip count for this contribution
indexOf(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
Retrieve the index of where a specified column is located based on the name parameter.
InfiniteLoopReader - org.springframework.batch.sample.common中的类
ItemReader implementation that will continually return a new object.
InfiniteLoopReader() - 类 的构造器org.springframework.batch.sample.common.InfiniteLoopReader
 
InfiniteLoopWriter - org.springframework.batch.sample.common中的类
Simple module implementation that will always return true to indicate that processing should continue.
InfiniteLoopWriter() - 类 的构造器org.springframework.batch.sample.common.InfiniteLoopWriter
 
init() - 类 中的方法org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
init() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrNamespaceHandler
 
init() - 类 中的方法org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
 
init() - 类 中的方法org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
 
init() - 类 中的方法org.springframework.batch.item.data.GemfireItemWriter
 
init() - 类 中的方法org.springframework.batch.item.KeyValueItemWriter
afterPropertiesSet() hook
init(DataSource) - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
Initialize the query provider using the provided DataSource if necessary.
init(DataSource) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Check mandatory properties.
init(DataSource) - 类 中的方法org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
initBinder(DataBinder) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Initialize a new binder instance.
initDao() - 类 中的方法org.springframework.batch.sample.common.StagingItemWriter
Check mandatory properties.
initDao() - 类 中的方法org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
initialize() - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
initialize() - 类 中的方法org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
Sets up the basic components by extracting them from the configurer, defaulting to some sensible values as long as a unique DataSource is available.
initialize() - 类 中的方法org.springframework.batch.sample.config.DataSourceConfiguration
 
initializeConnection() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
 
initializeProxy() - 类 中的方法org.springframework.batch.container.jms.BatchMessageListenerContainer
 
initializeUserData(Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
initializeUserData(Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to allow them to memorise the contents of the inputs, in case they are needed for accounting purposes later.
initNamespaceContext(XMLEventWriter) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Inits the namespace context of the XMLEventWriter: rootTagNamespacePrefix for rootTagName any other xmlns namespace prefix declarations in the root element attributes
initProperties(Element) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
InlineFlowParser - org.springframework.batch.core.configuration.xml中的类
 
InlineFlowParser(String, String) - 类 的构造器org.springframework.batch.core.configuration.xml.InlineFlowParser
Construct a InlineFlowParser with the specified name and using the provided job repository ref.
InlineStepParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <step/> elements inside a job.
InlineStepParser() - 类 的构造器org.springframework.batch.core.configuration.xml.InlineStepParser
 
inputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the input channel on which items sent by the master are received.
inputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the input channel on which replies from workers will be received.
inputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the input channel on which step execution requests sent by the master are received.
inputChannel(PollableChannel) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Set the input channel on which replies from workers will be received.
INSERT_PLAYER - 类 中的静态变量org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
insertCustomer(String, BigDecimal) - 接口 中的方法org.springframework.batch.sample.domain.trade.CustomerDao
 
insertCustomer(String, BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
IntArrayPropertyEditor - org.springframework.batch.support中的类
 
IntArrayPropertyEditor() - 类 的构造器org.springframework.batch.support.IntArrayPropertyEditor
 
intValue(String) - 接口 中的方法org.springframework.batch.core.launch.support.ExitCodeMapper
Convert the exit code from String into an integer that the calling environment as an operating system can interpret as an exit status.
intValue(String) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
Get the operating system exit status that matches a certain Batch Framework exit code
InvalidCustomerLogger - org.springframework.batch.sample.domain.trade中的接口
Interface for logging invalid customers.
InvocationTargetThrowableWrapper(Throwable) - 异常错误 的构造器org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper
 
invoke(MethodInvocation) - 类 中的方法org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 
invoke(MethodInvocation) - 类 中的方法org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
invoke(MethodInvocation) - 类 中的方法org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Invoke the proceeding method call repeatedly, according to the properties of the injected RepeatOperations.
invokeDelegateMethod() - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invoker the target method with arguments set by AbstractMethodInvokingDelegator.setArguments(Object[]).
invokeDelegateMethodWithArgument(Object) - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invokes the target method with given argument.
invokeDelegateMethodWithArguments(Object[]) - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invokes the target method with given arguments.
invokeMethod(Object...) - 接口 中的方法org.springframework.batch.support.MethodInvoker
 
invokeMethod(Object...) - 类 中的方法org.springframework.batch.support.SimpleMethodInvoker
 
isAbandon() - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
 
isAbstract(Element) - 类 中的静态方法org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
 
isAllowStartIfComplete() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
isAllowStartIfComplete() - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
isAllowStartIfComplete() - 接口 中的方法org.springframework.batch.core.Step
 
isAutoStartup() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
isBusinessCustomer() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
isBusy() - 类 中的方法org.springframework.batch.core.step.item.Chunk
Query the chunk to see if anyone has registered an interest in keeping a reference to it.
isCloseSuppressionActive(Connection) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Return the status of close suppression being activated for a given Connection
isComplete() - 类 中的方法org.springframework.batch.core.scope.context.ChunkContext
 
isComplete() - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
isComplete() - 类 中的方法org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
isComplete(Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
isComplete(Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to store additional data in the inputs.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
isComplete(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.CompletionPolicy
Allow policy to signal completion according to internal state, without having to wait for the callback to complete.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CompletionPolicySupport
Always true.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
Always false.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Check the timeout and complete gracefully if it has expires.
isComplete(RepeatContext) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Delegate to CompletionPolicy.
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
isComplete(RepeatContext, RepeatStatus) - 接口 中的方法org.springframework.batch.repeat.CompletionPolicy
Determine whether a batch is complete given the latest result from the callback.
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.policy.CompletionPolicySupport
If exit status is not continuable return true, otherwise delegate to CompletionPolicySupport.isComplete(RepeatContext).
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
True if the result is null, or a RepeatStatus indicating completion.
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached, or the result is null.
isComplete(RepeatContext, RepeatStatus) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
isCompleteOnly() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
isCompleteOnly() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Public accessor for the complete flag.
isContinuable() - 枚举 中的方法org.springframework.batch.repeat.RepeatStatus
 
isCopyConfiguration() - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Protected access for subclasses to the flag determining whether configuration should be copied from parent context.
isDirty() - 类 中的方法org.springframework.batch.item.ExecutionContext
Indicates if context has been changed with a "put" operation since the dirty flag was last cleared.
isEagerInit() - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
isEagerInit() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
isEmpty() - 类 中的方法org.springframework.batch.core.JobParameters
 
isEmpty() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
isEmpty() - 类 中的方法org.springframework.batch.item.ExecutionContext
Indicates whether or not the context is empty.
isEmpty() - 类 中的方法org.springframework.batch.repeat.support.ResultHolderResultQueue
 
isEmpty() - 类 中的方法org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
isEnd() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isEnd() - 类 中的方法org.springframework.batch.core.job.flow.support.StateTransition
Check for a special next State signalling the end of a job.
isEnd() - 类 中的方法org.springframework.batch.core.step.item.Chunk
Flag to indicate if the source data is exhausted.
isEndOfRecord(String) - 类 中的方法org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Return true if the line does not have unterminated quotes (delimited by "), and does not end with a continuation marker ('\').
isEndOfRecord(String) - 类 中的方法org.springframework.batch.item.file.separator.JsonRecordSeparatorPolicy
True if the line can be parsed to a JSON object.
isEndOfRecord(String) - 接口 中的方法org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Signal the end of a record based on the content of the current record.
isEndOfRecord(String) - 类 中的方法org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Always returns true.
isEndOfRecord(String) - 类 中的方法org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Return true if the line ends with the specified substring.
isEndState() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
isEndState() - 接口 中的方法org.springframework.batch.core.job.flow.State
Inquire as to whether a State is an end state.
isEndState() - 类 中的方法org.springframework.batch.core.job.flow.support.state.DecisionState
 
isEndState() - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
 
isEndState() - 类 中的方法org.springframework.batch.core.job.flow.support.state.FlowState
 
isEndState() - 类 中的方法org.springframework.batch.core.job.flow.support.state.SplitState
 
isEndState() - 类 中的方法org.springframework.batch.core.job.flow.support.state.StepState
 
isExistingTransaction(Object) - 类 中的方法org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
isExpecting() - 类 中的方法org.springframework.batch.repeat.support.ResultHolderResultQueue
 
isExpecting() - 类 中的方法org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
isFail() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isFaultTolerant() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
isFlowContinued(State, FlowExecutionStatus, StepExecution) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
isFlowContinued(State, FlowExecutionStatus, StepExecution) - 类 中的方法org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
isFooter() - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItem
Responds true if this record is a footer in an aggregate.
isGreaterThan(BatchStatus) - 枚举 中的方法org.springframework.batch.core.BatchStatus
 
isHeader() - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItem
Responds true if this record is a header in an aggregate.
isIdentifying() - 类 中的方法org.springframework.batch.core.JobParameter
 
ISIN_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
ISIN_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
isInitialized() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
isJobInstanceExists(String, JobParameters) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Check if an instance of this job already exists with the parameters provided.
isJobInstanceExists(String, JobParameters) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
isLessThan(BatchStatus) - 枚举 中的方法org.springframework.batch.core.BatchStatus
 
isLessThanOrEqualTo(BatchStatus) - 枚举 中的方法org.springframework.batch.core.BatchStatus
 
isListener(Object) - 类 中的静态方法org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to check whether the given object is or can be made into a JobExecutionListener.
isListener(Object) - 类 中的静态方法org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to check whether the given object is or can be made into a StepListener.
isListener(Object, Class<?>, ListenerMetaData[]) - 类 中的静态方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
Convenience method to check whether the given object is or can be made into a listener.
isNew(Object[]) - 类 中的方法org.springframework.batch.item.jms.JmsNewMethodArgumentsIdentifier
If any of the arguments is a message, check the JMS re-delivered flag and return it, otherwise return false to be on the safe side.
isNonDefaultExitStatus(ExitStatus) - 类 中的静态方法org.springframework.batch.core.ExitStatus
 
isPrototype() - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
isPrototype() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
isQuoteCharacter(char) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Is the supplied character a quote character?
isReaderTransactionalQueue() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
isReaderTransactionalQueue() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Convenience method for subclasses.
isRedelivered() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
isRegistered() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
isRestart() - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
 
isRestart() - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
isRestartable() - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
isRestartable() - 类 中的方法org.springframework.batch.core.job.AbstractJob
 
isRestartable() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
 
isRestartable() - 接口 中的方法org.springframework.batch.core.Job
Flag to indicate if this job can be restarted, at least in principle.
isRunning() - 枚举 中的方法org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates work is in progress.
isRunning() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Check if this component has been started.
isRunning() - 类 中的方法org.springframework.batch.core.ExitStatus
Check if this status represents a running process.
isRunning() - 类 中的方法org.springframework.batch.core.JobExecution
Test if this JobExecution indicates that it is running.
isSaveState() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The flag that determines whether to save internal state for restarts.
isSingleton() - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Optimization hint for bean factory.
isSingleton() - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
isSingleton() - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Returns true by default, but in most cases a Step should not be treated as thread-safe.
isSingleton() - 类 中的方法org.springframework.batch.core.step.StepLocatorStepFactoryBean
Always return true as optimization for bean factory.
isSingleton() - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Optimization for the bean factory (always returns true).
isSingleton() - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Always returns true.
isStartable(StepExecution, ExecutionContext) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check if a step execution is startable.
isStatelessSession() - 类 中的方法org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
isStop() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isStopping() - 类 中的方法org.springframework.batch.core.JobExecution
Test if this JobExecution indicates that it has been signalled to stop.
isStrict() - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
Provides access to the strict flag for subclasses if needed.
isSuccessful() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
isSupportedIncrementerType(String) - 接口 中的方法org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Returns boolean indicated whether or not the provided string is supported by this factory.
isSupportedIncrementerType(String) - 类 中的方法org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
isTerminateOnly() - 类 中的方法org.springframework.batch.core.StepExecution
 
isTerminateOnly() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
isTerminateOnly() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Public accessor for the termination flag.
isUnderspecified(Element) - 类 中的静态方法org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
Should this element be treated as incomplete?
isUnsuccessful() - 枚举 中的方法org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates execution was unsuccessful.
isUseSharedExtendedConnection() - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
 
isUsingNamedParameters() - 接口 中的方法org.springframework.batch.item.database.PagingQueryProvider
Indicate whether the generated queries use named parameter syntax.
isUsingNamedParameters() - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
isVip() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
isWrapperFor(Class<?>) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Performs only a 'shallow' non-recursive check of self's and delegate's class to retain Java 5 compatibility.
ITEM_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
itemBindingVariableName(String) - 类 中的方法org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Provides the ability to change the key name that scripts use to obtain the current item to process if the variable represented by: ScriptItemProcessor.ITEM_BINDING_VARIABLE_NAME is not suitable ("item").
ItemCountAware - org.springframework.batch.item中的接口
Marker interface indicating that an item should have the item count set on it.
itemCountLimitPerResource(int) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
After this limit is exceeded the next chunk will be written into newly created resource.
itemKeyMapper - 类 中的变量org.springframework.batch.item.KeyValueItemWriter
 
itemKeyMapper(Converter<V, K>) - 类 中的方法org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Set the Converter to use to derive the key from the item.
itemListenerMetaData() - 枚举 中的静态方法org.springframework.batch.core.listener.StepListenerMetaData
 
ItemListenerSupport<I,​O> - org.springframework.batch.core.listener中的类
Basic no-op implementation of the ItemReadListener, ItemProcessListener, and ItemWriteListener interfaces.
ItemListenerSupport() - 类 的构造器org.springframework.batch.core.listener.ItemListenerSupport
 
itemPreparedStatementSetter(ItemPreparedStatementSetter<T>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Configures a ItemPreparedStatementSetter for use by the writer.
ItemPreparedStatementSetter<T> - org.springframework.batch.item.database中的接口
A convenient strategy for SQL updates, acting effectively as the inverse of RowMapper.
ItemProcessListener<T,​S> - org.springframework.batch.core中的接口
Listener interface for the processing of an item.
ItemProcessListenerAdapter<T,​S> - org.springframework.batch.core.jsr中的类
Wrapper class for ItemProcessListener
ItemProcessListenerAdapter(ItemProcessListener) - 类 的构造器org.springframework.batch.core.jsr.ItemProcessListenerAdapter
 
itemProcessor() - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
itemProcessor() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringProcessSample
 
itemProcessor() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringReadSample
 
itemProcessor() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringWriteSample
 
itemProcessor(ItemProcessor<I, O>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the ItemProcessor to use to process items sent by the master step.
ItemProcessor<I,​O> - org.springframework.batch.item中的接口
Interface for item transformation.
ItemProcessorAdapter<I,​O> - org.springframework.batch.item.adapter中的类
Invokes a custom method on a delegate plain old Java object which itself processes an item.
ItemProcessorAdapter<I,​O> - org.springframework.batch.jsr.item中的类
 
ItemProcessorAdapter() - 类 的构造器org.springframework.batch.item.adapter.ItemProcessorAdapter
 
ItemProcessorAdapter(ItemProcessor) - 类 的构造器org.springframework.batch.jsr.item.ItemProcessorAdapter
 
itemReader - 类 中的变量org.springframework.batch.core.step.item.SimpleChunkProvider
 
itemReader() - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
itemReader() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringProcessSample
 
itemReader() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringReadSample
 
itemReader() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringWriteSample
 
itemReader() - 类 中的方法org.springframework.batch.sample.validation.ValidationSampleConfiguration
 
ItemReader<T> - org.springframework.batch.item中的接口
Strategy interface for providing the data.
ItemReaderAdapter<T> - org.springframework.batch.item.adapter中的类
Invokes a custom method on a delegate plain old Java object which itself provides an item.
ItemReaderAdapter<T> - org.springframework.batch.jsr.item中的类
Adapter that wraps an ItemReader for use by Spring Batch.
ItemReaderAdapter() - 类 的构造器org.springframework.batch.item.adapter.ItemReaderAdapter
 
ItemReaderAdapter(ItemReader) - 类 的构造器org.springframework.batch.jsr.item.ItemReaderAdapter
 
ItemReaderException - org.springframework.batch.item中的异常错误
A base exception class that all exceptions thrown from an ItemReader extend.
ItemReaderException(String) - 异常错误 的构造器org.springframework.batch.item.ItemReaderException
Create a new ItemReaderException based on a message.
ItemReaderException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.ItemReaderException
Create a new ItemReaderException based on a message and another exception.
ItemReadListener<T> - org.springframework.batch.core中的接口
Listener interface around the reading of an item.
ItemReadListenerAdapter<T> - org.springframework.batch.core.jsr中的类
Wrapper class to adapt the ItemReadListener to a ItemReadListener.
ItemReadListenerAdapter(ItemReadListener) - 类 的构造器org.springframework.batch.core.jsr.ItemReadListenerAdapter
 
itemSqlParameterSourceProvider(ItemSqlParameterSourceProvider<T>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Configures a ItemSqlParameterSourceProvider for use by the writer.
ItemSqlParameterSourceProvider<T> - org.springframework.batch.item.database中的接口
A convenient strategy for providing SqlParameterSource for named parameter SQL updates.
ItemStream - org.springframework.batch.item中的接口
Marker interface defining a contract for periodically storing state and restoring from that state should an error occur.
ItemStreamException - org.springframework.batch.item中的异常错误
Exception representing any errors encountered while processing a stream.
ItemStreamException(String) - 异常错误 的构造器org.springframework.batch.item.ItemStreamException
 
ItemStreamException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.ItemStreamException
Constructs a new instance with a message and nested exception.
ItemStreamException(Throwable) - 异常错误 的构造器org.springframework.batch.item.ItemStreamException
Constructs a new instance with a nested exception and empty message.
ItemStreamReader<T> - org.springframework.batch.item中的接口
Convenience interface that combines ItemStream and ItemReader .
ItemStreamSupport - org.springframework.batch.item中的类
Empty method implementation of ItemStream.
ItemStreamSupport() - 类 的构造器org.springframework.batch.item.ItemStreamSupport
 
ItemStreamWriter<T> - org.springframework.batch.item中的接口
Convenience interface that combines ItemStream and ItemWriter .
itemType - 类 中的变量org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
 
itemType - 类 中的变量org.springframework.batch.item.jms.JmsItemReader
 
itemType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
Establish the itemType for the reader.
itemType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
Set the expected type of incoming message payloads.
itemValidator() - 类 中的方法org.springframework.batch.sample.validation.ValidationSampleConfiguration
 
ItemWriteListener<S> - org.springframework.batch.core中的接口
Listener interface for the writing of items.
ItemWriteListenerAdapter<S> - org.springframework.batch.core.jsr中的类
Wrapper class to adapt the ItemWriteListener to a ItemWriteListener.
ItemWriteListenerAdapter(ItemWriteListener) - 类 的构造器org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
itemWriter() - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
itemWriter() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringProcessSample
 
itemWriter() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringReadSample
 
itemWriter() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringWriteSample
 
itemWriter() - 类 中的方法org.springframework.batch.sample.validation.ValidationSampleConfiguration
 
itemWriter(ItemWriter<O>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the ItemWriter to use to write items sent by the master step.
ItemWriter<T> - org.springframework.batch.item中的接口
Basic interface for generic output operations.
ItemWriterAdapter<T> - org.springframework.batch.item.adapter中的类
Delegates item processing to a custom method - passes the item as an argument for the delegate method.
ItemWriterAdapter<T> - org.springframework.batch.jsr.item中的类
Adapter that wraps an ItemWriter for use by Spring Batch.
ItemWriterAdapter() - 类 的构造器org.springframework.batch.item.adapter.ItemWriterAdapter
 
ItemWriterAdapter(ItemWriter) - 类 的构造器org.springframework.batch.jsr.item.ItemWriterAdapter
 
ItemWriterException - org.springframework.batch.item中的异常错误
A base exception class that all exceptions thrown from an ItemWriter extend.
ItemWriterException(String) - 异常错误 的构造器org.springframework.batch.item.ItemWriterException
Create a new ItemWriterException based on a message.
ItemWriterException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.ItemWriterException
Create a new ItemWriterException based on a message and another exception.
iterate(RepeatCallback) - 接口 中的方法org.springframework.batch.repeat.RepeatOperations
Execute the callback repeatedly, until a decision can be made to complete.
iterate(RepeatCallback) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Execute the batch callback until the completion policy decides that we are finished.
iterator() - 类 中的方法org.springframework.batch.core.step.item.Chunk
Get an unmodifiable iterator for the underlying items.
IteratorItemReader<T> - org.springframework.batch.item.support中的类
An ItemReader that pulls data from a Iterator or Iterable using the constructors.
IteratorItemReader(Iterable<T>) - 类 的构造器org.springframework.batch.item.support.IteratorItemReader
Construct a new reader from this iterable (could be a collection), by extracting an instance of Iterator from it.
IteratorItemReader(Iterator<T>) - 类 的构造器org.springframework.batch.item.support.IteratorItemReader
Construct a new reader from this iterator directly.

J

Jackson2ExecutionContextStringSerializer - org.springframework.batch.core.repository.dao中的类
Implementation that uses Jackson2 to provide (de)serialization.
Jackson2ExecutionContextStringSerializer() - 类 的构造器org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
JacksonJsonObjectMarshaller<T> - org.springframework.batch.item.json中的类
A json object marshaller that uses Jackson to marshal an object into a json representation.
JacksonJsonObjectMarshaller() - 类 的构造器org.springframework.batch.item.json.JacksonJsonObjectMarshaller
 
JacksonJsonObjectReader<T> - org.springframework.batch.item.json中的类
Implementation of JsonObjectReader based on Jackson.
JacksonJsonObjectReader(Class<? extends T>) - 类 的构造器org.springframework.batch.item.json.JacksonJsonObjectReader
Create a new JacksonJsonObjectReader instance.
JdbcBatchItemWriter<T> - org.springframework.batch.item.database中的类
ItemWriter that uses the batching features from NamedParameterJdbcTemplate to execute a batch of statements for all items provided.
JdbcBatchItemWriter() - 类 的构造器org.springframework.batch.item.database.JdbcBatchItemWriter
 
JdbcBatchItemWriterBuilder<T> - org.springframework.batch.item.database.builder中的类
A builder implementation for the JdbcBatchItemWriter.
JdbcBatchItemWriterBuilder() - 类 的构造器org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
 
JdbcCursorItemReader<T> - org.springframework.batch.item.database中的类
Simple item reader implementation that opens a JDBC cursor and continually retrieves the next row in the ResultSet.
JdbcCursorItemReader() - 类 的构造器org.springframework.batch.item.database.JdbcCursorItemReader
 
JdbcCursorItemReaderBuilder<T> - org.springframework.batch.item.database.builder中的类
Builder for the JdbcCursorItemReader
JdbcCursorItemReaderBuilder() - 类 的构造器org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
 
JdbcCustomerDao - org.springframework.batch.sample.domain.trade.internal中的类
 
JdbcCustomerDao() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
JdbcCustomerDebitDao - org.springframework.batch.sample.domain.trade.internal中的类
Reduces customer's credit by the provided amount.
JdbcCustomerDebitDao() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
JdbcExecutionContextDao - org.springframework.batch.core.repository.dao中的类
JDBC DAO for ExecutionContext.
JdbcExecutionContextDao() - 类 的构造器org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
JdbcGameDao - org.springframework.batch.sample.domain.football.internal中的类
 
JdbcGameDao() - 类 的构造器org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
JdbcJobExecutionDao - org.springframework.batch.core.repository.dao中的类
JDBC implementation of JobExecutionDao.
JdbcJobExecutionDao() - 类 的构造器org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
JdbcJobInstanceDao - org.springframework.batch.core.repository.dao中的类
JDBC implementation of JobInstanceDao.
JdbcJobInstanceDao() - 类 的构造器org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
JdbcPagingItemReader<T> - org.springframework.batch.item.database中的类
ItemReader for reading database records using JDBC in a paging fashion.
JdbcPagingItemReader() - 类 的构造器org.springframework.batch.item.database.JdbcPagingItemReader
 
JdbcPagingItemReaderBuilder<T> - org.springframework.batch.item.database.builder中的类
This is a builder for the JdbcPagingItemReader.
JdbcPagingItemReaderBuilder() - 类 的构造器org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
 
JdbcParameterUtils - org.springframework.batch.item.database中的类
Helper methods for SQL statement parameter parsing.
JdbcParameterUtils() - 类 的构造器org.springframework.batch.item.database.JdbcParameterUtils
 
JdbcPlayerDao - org.springframework.batch.sample.domain.football.internal中的类
 
JdbcPlayerDao() - 类 的构造器org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
JdbcPlayerSummaryDao - org.springframework.batch.sample.domain.football.internal中的类
 
JdbcPlayerSummaryDao() - 类 的构造器org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
JdbcStepExecutionDao - org.springframework.batch.core.repository.dao中的类
JDBC implementation of StepExecutionDao.
Allows customization of the tables names used by Spring Batch for step meta data via a prefix property.
Uses sequences or tables (via Spring's DataFieldMaxValueIncrementer abstraction) to create all primary keys before inserting a new row.
JdbcStepExecutionDao() - 类 的构造器org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
JdbcTradeDao - org.springframework.batch.sample.domain.trade.internal中的类
Writes a Trade object to a database
JdbcTradeDao() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
JmsItemReader<T> - org.springframework.batch.item.jms中的类
An ItemReader for JMS using a JmsTemplate.
JmsItemReader() - 类 的构造器org.springframework.batch.item.jms.JmsItemReader
 
JmsItemReaderBuilder<T> - org.springframework.batch.item.jms.builder中的类
Creates a fully qualified JmsItemReader.
JmsItemReaderBuilder() - 类 的构造器org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
 
JmsItemWriter<T> - org.springframework.batch.item.jms中的类
An ItemWriter for JMS using a JmsTemplate.
JmsItemWriter() - 类 的构造器org.springframework.batch.item.jms.JmsItemWriter
 
JmsItemWriterBuilder<T> - org.springframework.batch.item.jms.builder中的类
Creates a fully qualified JmsItemWriter.
JmsItemWriterBuilder() - 类 的构造器org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
 
JmsMethodArgumentsKeyGenerator - org.springframework.batch.item.jms中的类
A MethodArgumentsKeyGenerator for JMS
JmsMethodArgumentsKeyGenerator() - 类 的构造器org.springframework.batch.item.jms.JmsMethodArgumentsKeyGenerator
 
JmsMethodInvocationRecoverer<T> - org.springframework.batch.item.jms中的类
 
JmsMethodInvocationRecoverer() - 类 的构造器org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
 
JmsNewMethodArgumentsIdentifier<T> - org.springframework.batch.item.jms中的类
A NewMethodArgumentsIdentifier for JMS that looks for a message in the arguments and checks its delivery status.
JmsNewMethodArgumentsIdentifier() - 类 的构造器org.springframework.batch.item.jms.JmsNewMethodArgumentsIdentifier
 
JmsRedeliveredExtractor - org.springframework.batch.integration.chunk中的类
 
JmsRedeliveredExtractor() - 类 的构造器org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 
jmsTemplate - 类 中的变量org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
 
jmsTemplate - 类 中的变量org.springframework.batch.item.jms.JmsItemReader
 
jmsTemplate(JmsOperations) - 类 中的方法org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
Establish the JMS template that will be used by the JmsItemReader.
jmsTemplate(JmsOperations) - 类 中的方法org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
Establish the JMS template that will be used by the JmsItemWriter.
job() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringProcessSample
 
job() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringReadSample
 
job() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringWriteSample
 
job() - 类 中的方法org.springframework.batch.sample.validation.ValidationSampleConfiguration
 
job(Job) - 类 中的方法org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job to execute during the step.
job(Job) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Create a new step builder that will execute a job.
job(Job) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
Job - org.springframework.batch.core中的接口
Batch domain object representing a job.
JOB - org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
 
JOB_NOT_PROVIDED - 接口 中的静态变量org.springframework.batch.core.launch.support.ExitCodeMapper
 
JOB_RUN_ID - 类 中的静态变量org.springframework.batch.core.jsr.JsrJobParametersConverter
 
JobBuilder - org.springframework.batch.core.job.builder中的类
Convenience for building jobs of various kinds.
JobBuilder(String) - 类 的构造器org.springframework.batch.core.job.builder.JobBuilder
Create a new builder for a job with the given name.
JobBuilderException - org.springframework.batch.core.job.builder中的异常错误
 
JobBuilderException(Exception) - 异常错误 的构造器org.springframework.batch.core.job.builder.JobBuilderException
 
JobBuilderFactory - org.springframework.batch.core.configuration.annotation中的类
Convenient factory for a JobBuilder which sets the JobRepository automatically.
JobBuilderFactory(JobRepository) - 类 的构造器org.springframework.batch.core.configuration.annotation.JobBuilderFactory
 
JobBuilderHelper<B extends JobBuilderHelper<B>> - org.springframework.batch.core.job.builder中的类
A base class and utility for other job builders providing access to common properties like job repository.
JobBuilderHelper(String) - 类 的构造器org.springframework.batch.core.job.builder.JobBuilderHelper
 
JobBuilderHelper(JobBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.job.builder.JobBuilderHelper
Create a new builder initialized with any properties in the parent.
JobBuilderHelper.CommonJobProperties - org.springframework.batch.core.job.builder中的类
 
jobBuilders() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
JobContext - org.springframework.batch.core.scope.context中的类
A context object that can be used to interrogate the current JobExecution and some of its associated properties using expressions based on bean paths.
JobContext(JobExecution) - 类 的构造器org.springframework.batch.core.scope.context.JobContext
 
JobExecution - org.springframework.batch.core中的类
Batch domain object representing the execution of a job.
JobExecution(Long) - 类 的构造器org.springframework.batch.core.JobExecution
 
JobExecution(Long, JobParameters) - 类 的构造器org.springframework.batch.core.JobExecution
 
JobExecution(Long, JobParameters, String) - 类 的构造器org.springframework.batch.core.JobExecution
 
JobExecution(JobExecution) - 类 的构造器org.springframework.batch.core.JobExecution
 
JobExecution(JobInstance, Long, JobParameters, String) - 类 的构造器org.springframework.batch.core.JobExecution
Because a JobExecution isn't valid unless the job is set, this constructor is the only valid one from a modeling point of view.
JobExecution(JobInstance, JobParameters) - 类 的构造器org.springframework.batch.core.JobExecution
Constructor for transient (unsaved) instances.
JobExecution(JobInstance, JobParameters, String) - 类 的构造器org.springframework.batch.core.JobExecution
 
JobExecutionAlreadyRunningException - org.springframework.batch.core.repository中的异常错误
 
JobExecutionAlreadyRunningException(String) - 异常错误 的构造器org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionAlreadyRunningException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionDao - org.springframework.batch.core.repository.dao中的接口
Data Access Object for job executions.
JobExecutionDecider - org.springframework.batch.core.job.flow中的接口
Interface allowing for programmatic access to the decision on what the status of a flow should be.
JobExecutionException - org.springframework.batch.core中的异常错误
Root of exception hierarchy for checked exceptions in job and step execution.
JobExecutionException(String) - 异常错误 的构造器org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message.
JobExecutionException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message and a cause.
JobExecutionListener - org.springframework.batch.core中的接口
Provide callbacks at specific points in the lifecycle of a Job.
JobExecutionListenerParser - org.springframework.batch.core.configuration.xml中的类
Parser for a step listener element.
JobExecutionListenerParser() - 类 的构造器org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
JobExecutionListenerSupport - org.springframework.batch.core.listener中的类
 
JobExecutionListenerSupport() - 类 的构造器org.springframework.batch.core.listener.JobExecutionListenerSupport
 
JobExecutionNotFailedException - org.springframework.batch.core.launch中的异常错误
Checked exception to indicate that user asked for a job execution to be resumed when actually it didn't fail.
JobExecutionNotFailedException(String) - 异常错误 的构造器org.springframework.batch.core.launch.JobExecutionNotFailedException
Create an exception with the given message.
JobExecutionNotFailedException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.launch.JobExecutionNotFailedException
 
JobExecutionNotificationPublisher - org.springframework.batch.sample.jmx中的类
JMX notification broadcaster
JobExecutionNotificationPublisher() - 类 的构造器org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
 
JobExecutionNotRunningException - org.springframework.batch.core.launch中的异常错误
Execution indicating that a JobExecution that is not currently running has been requested to stop.
JobExecutionNotRunningException(String) - 异常错误 的构造器org.springframework.batch.core.launch.JobExecutionNotRunningException
Create a JobExecutionNotRunningException with a message.
JobExecutionNotStoppedException - org.springframework.batch.core.launch中的异常错误
Checked exception to indicate that user asked for a job execution to be aborted when hasn't been stopped.
JobExecutionNotStoppedException(String) - 异常错误 的构造器org.springframework.batch.core.launch.JobExecutionNotStoppedException
Create an exception with the given message.
jobExplorer() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobExplorer() - 类 中的方法org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobExplorer() - 类 中的方法org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
jobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the job explorer.
jobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the job explorer.
JobExplorer - org.springframework.batch.core.explore中的接口
Entry point for browsing executions of running or historical jobs and steps.
JobExplorerFactoryBean - org.springframework.batch.core.explore.support中的类
A FactoryBean that automates the creation of a SimpleJobExplorer using JDBC DAO implementations.
JobExplorerFactoryBean() - 类 的构造器org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
JobFactory - org.springframework.batch.core.configuration中的接口
Strategy for creating a single job.
JobFactoryBean - org.springframework.batch.core.jsr.configuration.xml中的类
This FactoryBean is used by the JSR-352 namespace parser to create FlowJob objects.
JobFactoryBean(String) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
JobFactoryRegistrationListener - org.springframework.batch.core.configuration.support中的类
Generic service that can bind and unbind a JobFactory in a JobRegistry.
JobFactoryRegistrationListener() - 类 的构造器org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
 
JobFlowBuilder - org.springframework.batch.core.job.builder中的类
 
JobFlowBuilder(FlowJobBuilder) - 类 的构造器org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Flow) - 类 的构造器org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, JobExecutionDecider) - 类 的构造器org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Step) - 类 的构造器org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowExecutor - org.springframework.batch.core.job.flow中的类
Implementation of FlowExecutor for use in components that need to execute a flow related to a JobExecution.
JobFlowExecutor(JobRepository, StepHandler, JobExecution) - 类 的构造器org.springframework.batch.core.job.flow.JobFlowExecutor
 
JobInstance - org.springframework.batch.core中的类
Batch domain object representing a uniquely identifiable job run.
JobInstance(Long, String) - 类 的构造器org.springframework.batch.core.JobInstance
 
JobInstanceAlreadyCompleteException - org.springframework.batch.core.repository中的异常错误
An exception indicating an illegal attempt to restart a job that was already completed successfully.
JobInstanceAlreadyCompleteException(String) - 异常错误 的构造器org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyCompleteException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyExistsException - org.springframework.batch.core.launch中的异常错误
Checked exception to indicate that a required Job is not available.
JobInstanceAlreadyExistsException(String) - 异常错误 的构造器org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
Create an exception with the given message.
JobInstanceAlreadyExistsException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
 
JobInstanceDao - org.springframework.batch.core.repository.dao中的接口
Data Access Object for job instances.
JobInterruptedException - org.springframework.batch.core中的异常错误
Exception to indicate the the job has been interrupted.
JobInterruptedException(String) - 异常错误 的构造器org.springframework.batch.core.JobInterruptedException
 
JobInterruptedException(String, BatchStatus) - 异常错误 的构造器org.springframework.batch.core.JobInterruptedException
 
JobKeyGenerator<T> - org.springframework.batch.core中的接口
Strategy interface for the generation of the key used in identifying unique JobInstance.
jobLauncher() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobLauncher() - 类 中的方法org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobLauncher() - 类 中的方法org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobLauncher - org.springframework.batch.core.launch中的接口
Simple interface for controlling jobs, including possible ad-hoc executions, based on different runtime identifiers.
JobLauncherDetails - org.springframework.batch.sample.quartz中的类
 
JobLauncherDetails() - 类 的构造器org.springframework.batch.sample.quartz.JobLauncherDetails
 
JobLauncherTestUtils - org.springframework.batch.test中的类
Utility class for testing batch jobs.
JobLauncherTestUtils() - 类 的构造器org.springframework.batch.test.JobLauncherTestUtils
 
JobLaunchingGateway - org.springframework.batch.integration.launch中的类
The JobLaunchingGateway is used to launch Batch Jobs.
JobLaunchingGateway(JobLauncher) - 类 的构造器org.springframework.batch.integration.launch.JobLaunchingGateway
Constructor taking a JobLauncher as parameter.
JobLaunchingGatewayParser - org.springframework.batch.integration.config.xml中的类
The parser for the Job-Launching Gateway, which will instantiate a JobLaunchingGatewayParser.
JobLaunchingGatewayParser() - 类 的构造器org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
JobLaunchingMessageHandler - org.springframework.batch.integration.launch中的类
Message handler which uses strategies to convert a Message into a job and a set of job parameters
JobLaunchingMessageHandler(JobLauncher) - 类 的构造器org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
JobLaunchRequest - org.springframework.batch.integration.launch中的类
Encapsulation of a Job and its JobParameters forming a request for a job to be launched.
JobLaunchRequest(Job, JobParameters) - 类 的构造器org.springframework.batch.integration.launch.JobLaunchRequest
 
JobLaunchRequestHandler - org.springframework.batch.integration.launch中的接口
Interface for handling a JobLaunchRequest and returning a JobExecution.
JobLevelBeanLazyInitializer(ConfigurableListableBeanFactory) - 类 的构造器org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor.JobLevelBeanLazyInitializer
 
JobListenerAdapter - org.springframework.batch.core.jsr中的类
Wrapper class to adapt the JobListener to a JobExecutionListener.
JobListenerAdapter(JobListener) - 类 的构造器org.springframework.batch.core.jsr.JobListenerAdapter
 
JobListenerFactoryBean - org.springframework.batch.core.listener中的类
This AbstractListenerFactoryBean implementation is used to create a JobExecutionListener.
JobListenerFactoryBean() - 类 的构造器org.springframework.batch.core.listener.JobListenerFactoryBean
 
JobListenerMetaData - org.springframework.batch.core.listener中的枚举
Enumeration for JobExecutionListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
JobLoader - org.springframework.batch.core.configuration.support中的接口
 
JobLoader - org.springframework.batch.sample.launch中的接口
 
JobLocator - org.springframework.batch.core.configuration中的接口
A runtime service locator interface for retrieving job configurations by name.
JobOperator - org.springframework.batch.core.launch中的接口
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobParameter - org.springframework.batch.core中的类
Domain representation of a parameter to a batch job.
JobParameter(Double) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter(Double, boolean) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter(Long) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Long, boolean) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(String) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(String, boolean) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Date) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Date, boolean) - 类 的构造器org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter.ParameterType - org.springframework.batch.core中的枚举
Enumeration representing the type of a JobParameter.
JobParameterExecutionContextCopyListener - org.springframework.batch.core.listener中的类
This class can be used to automatically copy items from the JobParameters to the StepExecutionContext.
JobParameterExecutionContextCopyListener() - 类 的构造器org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
JobParameters - org.springframework.batch.core中的类
Value object representing runtime parameters to a batch job.
JobParameters() - 类 的构造器org.springframework.batch.core.JobParameters
 
JobParameters(Map<String, JobParameter>) - 类 的构造器org.springframework.batch.core.JobParameters
 
JobParametersBuilder - org.springframework.batch.core中的类
Helper class for creating JobParameters.
JobParametersBuilder() - 类 的构造器org.springframework.batch.core.JobParametersBuilder
Default constructor.
JobParametersBuilder(Properties) - 类 的构造器org.springframework.batch.core.JobParametersBuilder
Constructor to add conversion capabilities to support JSR-352.
JobParametersBuilder(JobExplorer) - 类 的构造器org.springframework.batch.core.JobParametersBuilder
 
JobParametersBuilder(JobParameters) - 类 的构造器org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersBuilder(JobParameters, JobExplorer) - 类 的构造器org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersConverter - org.springframework.batch.core.converter中的接口
A factory for JobParameters instances.
JobParametersExtractor - org.springframework.batch.core.step.job中的接口
Strategy interface for translating a StepExecution into JobParameters.
JobParametersIncrementer - org.springframework.batch.core中的接口
Interface for obtaining the next JobParameters in a sequence.
JobParametersInvalidException - org.springframework.batch.core中的异常错误
Exception for Job to signal that some JobParameters are invalid.
JobParametersInvalidException(String) - 异常错误 的构造器org.springframework.batch.core.JobParametersInvalidException
 
JobParametersNotFoundException - org.springframework.batch.core.launch中的异常错误
Checked exception to indicate that a required JobParametersIncrementer is not available.
JobParametersNotFoundException(String) - 异常错误 的构造器org.springframework.batch.core.launch.JobParametersNotFoundException
Create an exception with the given message.
JobParametersNotFoundException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.launch.JobParametersNotFoundException
 
JobParametersValidator - org.springframework.batch.core中的接口
Strategy interface for a Job to use in validating its parameters for an execution.
JobParser - org.springframework.batch.core.configuration.xml中的类
Parser for the <job/> element in the Batch namespace.
JobParser() - 类 的构造器org.springframework.batch.core.configuration.xml.JobParser
 
JobParserJobFactoryBean - org.springframework.batch.core.configuration.xml中的类
This FactoryBean is used by the batch namespace parser to create FlowJob objects.
JobParserJobFactoryBean(String) - 类 的构造器org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
jobRegistrar() - 类 中的方法org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRegistry() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRegistry() - 类 中的方法org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRegistry - org.springframework.batch.core.configuration中的接口
A runtime service registry interface for registering job configurations by name.
JobRegistryBackgroundJobRunner - org.springframework.batch.core.launch.support中的类
Command line launcher for registering jobs with a JobRegistry.
JobRegistryBackgroundJobRunner(String) - 类 的构造器org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
JobRegistryBeanPostProcessor - org.springframework.batch.core.configuration.support中的类
A BeanPostProcessor that registers Job beans with a JobRegistry.
JobRegistryBeanPostProcessor() - 类 的构造器org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
jobRepository() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRepository() - 类 中的方法org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRepository() - 类 中的方法org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRepository - org.springframework.batch.core.repository中的接口
Repository responsible for persistence of batch meta-data entities.
JobRepositoryFactoryBean - org.springframework.batch.core.repository.support中的类
A FactoryBean that automates the creation of a SimpleJobRepository using JDBC DAO implementations which persist batch metadata in database.
JobRepositoryFactoryBean() - 类 的构造器org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
JobRepositoryParser - org.springframework.batch.core.configuration.xml中的类
Parser for the <job-repository/> element in the Batch namespace.
JobRepositoryParser() - 类 的构造器org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
JobRepositoryTestUtils - org.springframework.batch.test中的类
Convenience class for creating and removing JobExecution instances from a database.
JobRepositoryTestUtils() - 类 的构造器org.springframework.batch.test.JobRepositoryTestUtils
Default constructor.
JobRepositoryTestUtils(JobRepository, DataSource) - 类 的构造器org.springframework.batch.test.JobRepositoryTestUtils
Create a JobRepositoryTestUtils with all its mandatory properties.
JobRestartException - org.springframework.batch.core.repository中的异常错误
An exception indicating an illegal attempt to restart a job.
JobRestartException(String) - 异常错误 的构造器org.springframework.batch.core.repository.JobRestartException
 
JobRestartException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.repository.JobRestartException
 
JobScope - org.springframework.batch.core.scope中的类
Scope for job context.
JobScope - org.springframework.batch.core.configuration.annotation中的注释类型
Convenient annotation for job scoped beans that defaults the proxy mode, so that it doesn't have to be specified explicitly on every bean definition.
JobScope() - 类 的构造器org.springframework.batch.core.scope.JobScope
 
JobScopeManager - org.springframework.batch.core.scope.context中的类
Convenient aspect to wrap a single threaded job execution, where the implementation of the Job is not job scope aware (i.e. not the ones provided by the framework).
JobScopeManager() - 类 的构造器org.springframework.batch.core.scope.context.JobScopeManager
 
JobScopeTestExecutionListener - org.springframework.batch.test中的类
A TestExecutionListener that sets up job-scope context for dependency injection into unit tests.
JobScopeTestExecutionListener() - 类 的构造器org.springframework.batch.test.JobScopeTestExecutionListener
 
JobScopeTestUtils - org.springframework.batch.test中的类
Utility class for creating and manipulating JobScope in unit tests.
JobScopeTestUtils() - 类 的构造器org.springframework.batch.test.JobScopeTestUtils
 
JobStep - org.springframework.batch.core.step.job中的类
A Step that delegates to a Job to do its work.
JobStep() - 类 的构造器org.springframework.batch.core.step.job.JobStep
 
JobStepBuilder - org.springframework.batch.core.step.builder中的类
A step builder for JobStep instances.
JobStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.JobStepBuilder
Create a new builder initialized with any properties in the parent.
JobSynchronizationManager - org.springframework.batch.core.scope.context中的类
Central convenience class for framework use in managing the job scope context.
JobSynchronizationManager() - 类 的构造器org.springframework.batch.core.scope.context.JobSynchronizationManager
 
JpaItemWriter<T> - org.springframework.batch.item.database中的类
ItemWriter that is using a JPA EntityManagerFactory to merge any Entities that aren't part of the persistence context.
JpaItemWriter() - 类 的构造器org.springframework.batch.item.database.JpaItemWriter
 
JpaItemWriterBuilder<T> - org.springframework.batch.item.database.builder中的类
A builder for the JpaItemWriter.
JpaItemWriterBuilder() - 类 的构造器org.springframework.batch.item.database.builder.JpaItemWriterBuilder
 
JpaNativeQueryProvider<E> - org.springframework.batch.item.database.orm中的类
This query provider creates JPA Querys from injected native SQL queries.
JpaNativeQueryProvider() - 类 的构造器org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
JpaPagingItemReader<T> - org.springframework.batch.item.database中的类
ItemReader for reading database records built on top of JPA.
JpaPagingItemReader() - 类 的构造器org.springframework.batch.item.database.JpaPagingItemReader
 
JpaPagingItemReaderBuilder<T> - org.springframework.batch.item.database.builder中的类
Creates a fully qualified JpaPagingItemReader.
JpaPagingItemReaderBuilder() - 类 的构造器org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
 
JpaQueryProvider - org.springframework.batch.item.database.orm中的接口
Interface defining the functionality to be provided for generating queries for use with JPA ItemReaders or other custom built artifacts.
JsonFileItemWriter<T> - org.springframework.batch.item.json中的类
Item writer that writes data in json format to an output file.
JsonFileItemWriter(Resource, JsonObjectMarshaller<T>) - 类 的构造器org.springframework.batch.item.json.JsonFileItemWriter
Create a new JsonFileItemWriter instance.
JsonFileItemWriterBuilder<T> - org.springframework.batch.item.json.builder中的类
Builder for JsonFileItemWriter.
JsonFileItemWriterBuilder() - 类 的构造器org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
 
JsonItemReader<T> - org.springframework.batch.item.json中的类
ItemStreamReader implementation that reads Json objects from a Resource having the following format:
JsonItemReader(Resource, JsonObjectReader<T>) - 类 的构造器org.springframework.batch.item.json.JsonItemReader
Create a new JsonItemReader instance.
JsonItemReaderBuilder<T> - org.springframework.batch.item.json.builder中的类
A builder for JsonItemReader.
JsonItemReaderBuilder() - 类 的构造器org.springframework.batch.item.json.builder.JsonItemReaderBuilder
 
JsonLineMapper - org.springframework.batch.item.file.mapping中的类
Interpret a line as a JSON object and parse it up to a Map.
JsonLineMapper() - 类 的构造器org.springframework.batch.item.file.mapping.JsonLineMapper
 
jsonObjectMarshaller(JsonObjectMarshaller<T>) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Set the JsonObjectMarshaller to use to marshal objects to json.
JsonObjectMarshaller<T> - org.springframework.batch.item.json中的接口
Strategy interface to marshal an object into a json representation.
jsonObjectReader(JsonObjectReader<T>) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Set the JsonObjectReader to use to read and map Json objects to domain objects.
JsonObjectReader<T> - org.springframework.batch.item.json中的接口
Strategy interface for Json readers.
jsonQuery(String) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
A JSON formatted MongoDB jsonQuery.
JsonRecordSeparatorPolicy - org.springframework.batch.item.file.separator中的类
JSON-based record separator.
JsonRecordSeparatorPolicy() - 类 的构造器org.springframework.batch.item.file.separator.JsonRecordSeparatorPolicy
 
JsrAutowiredAnnotationBeanPostProcessor - org.springframework.batch.core.jsr.configuration.support中的类
This class overrides methods in the copied SpringAutowiredAnnotationBeanPostProcessor class to check for the BatchProperty annotation before processing injection annotations.
JsrAutowiredAnnotationBeanPostProcessor() - 类 的构造器org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
 
JsrBatchletStepBuilder - org.springframework.batch.core.jsr.step.builder中的类
Extension of the TaskletStepBuilder that uses a BatchletStep instead of a TaskletStep.
JsrBatchletStepBuilder(StepBuilderHelper<? extends StepBuilderHelper<?>>) - 类 的构造器org.springframework.batch.core.jsr.step.builder.JsrBatchletStepBuilder
 
JsrBeanDefinitionDocumentReader - org.springframework.batch.core.jsr.configuration.xml中的类
DefaultBeanDefinitionDocumentReader extension to hook into the pre processing of the provided XML document, ensuring any references to property operators such as jobParameters and jobProperties are resolved prior to loading the context.
JsrBeanDefinitionDocumentReader() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
Creates a new JsrBeanDefinitionDocumentReader instance.
JsrBeanDefinitionDocumentReader(BeanDefinitionRegistry) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
Create a new JsrBeanDefinitionDocumentReader instance with the provided BeanDefinitionRegistry.
JsrBeanScopeBeanFactoryPostProcessor - org.springframework.batch.core.jsr.partition.support中的类
In order for property resolution to occur correctly within the scope of a JSR-352 batch job, initialization of job level artifacts must occur on the same thread that the job is executing.
JsrBeanScopeBeanFactoryPostProcessor() - 类 的构造器org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor
 
JsrBeanScopeBeanFactoryPostProcessor.JobLevelBeanLazyInitializer - org.springframework.batch.core.jsr.partition.support中的类
Looks for beans that may have dependencies that need to be lazily initialized and configures the corresponding BeanDefinition accordingly.
JsrChunkProcessor<I,​O> - org.springframework.batch.core.jsr.step.item中的类
ChunkProcessor implementation that implements JSR-352's chunking pattern (read and process in a loop until the chunk is complete then write).
JsrChunkProcessor() - 类 的构造器org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
 
JsrChunkProcessor(ItemReader<? extends I>, ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, RepeatOperations) - 类 的构造器org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
 
JsrChunkProvider<T> - org.springframework.batch.core.jsr.step.item中的类
A no-op ChunkProvider.
JsrChunkProvider() - 类 的构造器org.springframework.batch.core.jsr.step.item.JsrChunkProvider
 
JsrDecisionParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser for the <decision /> element as specified in JSR-352.
JsrDecisionParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrDecisionParser
 
JsrEndState - org.springframework.batch.core.jsr.job.flow.support.state中的类
State implementation for ending a job per JSR-352 rules if it is in progress and continuing if just starting.
JsrEndState(FlowExecutionStatus, String) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrEndState(FlowExecutionStatus, String, String) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrEndState(FlowExecutionStatus, String, String, boolean) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrEndState(FlowExecutionStatus, String, String, String, boolean, JobRepository) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrExpressionParser - org.springframework.batch.core.jsr.configuration.support中的类
Support class for parsing JSR-352 expressions.
JsrExpressionParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.support.JsrExpressionParser
Creates a new instance of this expression parser without and expression resolver.
JsrExpressionParser(BeanExpressionResolver, BeanExpressionContext) - 类 的构造器org.springframework.batch.core.jsr.configuration.support.JsrExpressionParser
Creates a new instances of this expression parser with the provided expression resolver and context to evaluate against.
JsrFaultTolerantChunkProcessor<I,​O> - org.springframework.batch.core.jsr.step.item中的类
Extension of the JsrChunkProcessor that adds skip and retry functionality.
JsrFaultTolerantChunkProcessor(ItemReader<? extends I>, ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, RepeatOperations, BatchRetryTemplate) - 类 的构造器org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
JsrFaultTolerantStepBuilder<I,​O> - org.springframework.batch.core.jsr.step.builder中的类
A step builder that extends the FaultTolerantStepBuilder to create JSR-352 specific ChunkProvider and ChunkProcessor supporting both the chunking pattern defined by the spec as well as skip/retry logic.
JsrFaultTolerantStepBuilder(StepBuilder) - 类 的构造器org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
JsrFlow - org.springframework.batch.core.jsr.job.flow.support中的类
Implements JSR-352 specific logic around the execution of a flow.
JsrFlow(String) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
JsrFlowExecutor - org.springframework.batch.core.jsr.job.flow中的类
JSR-352 specific JobFlowExecutor.
JsrFlowExecutor(JobRepository, StepHandler, JobExecution) - 类 的构造器org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
 
JsrFlowFactoryBean - org.springframework.batch.core.jsr.configuration.xml中的类
Extension to the SimpleFlowFactoryBean that provides JsrStepState implementations for JSR-352 based jobs.
JsrFlowFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrFlowFactoryBean
 
JsrFlowJob - org.springframework.batch.core.jsr.job.flow中的类
JSR-352 specific extension of the FlowJob.
JsrFlowJob() - 类 的构造器org.springframework.batch.core.jsr.job.flow.JsrFlowJob
No arg constructor (invalid state)
JsrFlowJob(String) - 类 的构造器org.springframework.batch.core.jsr.job.flow.JsrFlowJob
Main constructor
JsrJobContext - org.springframework.batch.core.jsr中的类
Wrapper class to provide the JobContext functionality as specified in JSR-352.
JsrJobContext() - 类 的构造器org.springframework.batch.core.jsr.JsrJobContext
 
JsrJobContextFactoryBean - org.springframework.batch.core.jsr中的类
Provides a single JobContext for each thread in a running job.
JsrJobContextFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
JsrJobExecution - org.springframework.batch.core.jsr中的类
Wrapper class to adapt the JobExecution to a JobExecution.
JsrJobExecution(JobExecution, JobParametersConverter) - 类 的构造器org.springframework.batch.core.jsr.JsrJobExecution
 
JsrJobListenerFactoryBean - org.springframework.batch.core.jsr.configuration.xml中的类
This FactoryBean is used by the JSR-352 namespace parser to create JobExecutionListener objects.
JsrJobListenerFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
JsrJobListenerMetaData - org.springframework.batch.core.jsr中的枚举
Enumeration for JobListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
JsrJobOperator - org.springframework.batch.core.jsr.launch中的类
The entrance for executing batch jobs as defined by JSR-352.
JsrJobOperator() - 类 的构造器org.springframework.batch.core.jsr.launch.JsrJobOperator
Public constructor used by BatchRuntime.getJobOperator().
JsrJobOperator(JobExplorer, JobRepository, JobParametersConverter, PlatformTransactionManager) - 类 的构造器org.springframework.batch.core.jsr.launch.JsrJobOperator
The no-arg constructor is used by the BatchRuntime.getJobOperator() and so bootstraps an ApplicationContext.
JsrJobOperator.BaseContextHolder - org.springframework.batch.core.jsr.launch中的类
A singleton holder used to lazily bootstrap the base context used in JSR-352.
JsrJobParametersConverter - org.springframework.batch.core.jsr中的类
Provides default conversion methodology for JSR-352's implementation.
JsrJobParametersConverter(DataSource) - 类 的构造器org.springframework.batch.core.jsr.JsrJobParametersConverter
Main constructor.
JsrJobParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parses a <job /> tag as defined in JSR-352.
JsrJobParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
 
JsrNamespaceHandler - org.springframework.batch.core.jsr.configuration.xml中的类
 
JsrNamespaceHandler() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrNamespaceHandler
 
JsrNamespacePostProcessor - org.springframework.batch.core.jsr.configuration.xml中的类
 
JsrNamespacePostProcessor() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
JsrPartitionHandler - org.springframework.batch.core.jsr.partition中的类
Executes a step instance per thread using a ThreadPoolTaskExecutor in accordance with JSR-352.
JsrPartitionHandler() - 类 的构造器org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
JsrPartitionHandler.PartitionPlanState - org.springframework.batch.core.jsr.partition中的类
Since a PartitionPlan could provide dynamic data (different results from run to run), the batch runtime needs to save off the results for restarts.
JsrPartitionStepBuilder - org.springframework.batch.core.jsr.step.builder中的类
An extension of the PartitionStepBuilder that uses PartitionStep so that JSR-352 specific semantics are honored.
JsrPartitionStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
JsrSampleBatchlet - org.springframework.batch.sample.jsr352中的类
Sample Batchlet implementation.
JsrSampleBatchlet() - 类 的构造器org.springframework.batch.sample.jsr352.JsrSampleBatchlet
 
JsrSampleItemProcessor - org.springframework.batch.sample.jsr352中的类
Sample ItemProcessor implementation.
JsrSampleItemProcessor() - 类 的构造器org.springframework.batch.sample.jsr352.JsrSampleItemProcessor
 
JsrSampleItemReader - org.springframework.batch.sample.jsr352中的类
Sample ItemReader implementation.
JsrSampleItemReader() - 类 的构造器org.springframework.batch.sample.jsr352.JsrSampleItemReader
 
JsrSampleItemWriter - org.springframework.batch.sample.jsr352中的类
Sample ItemWriter implementation.
JsrSampleItemWriter() - 类 的构造器org.springframework.batch.sample.jsr352.JsrSampleItemWriter
 
JsrSampleTasklet - org.springframework.batch.sample.jsr352中的类
Sample Tasklet implementation.
JsrSampleTasklet() - 类 的构造器org.springframework.batch.sample.jsr352.JsrSampleTasklet
 
JsrSimpleStepBuilder<I,​O> - org.springframework.batch.core.jsr.step.builder中的类
A step builder that extends the FaultTolerantStepBuilder to create JSR-352 specific ChunkProvider and ChunkProcessor supporting the chunking pattern defined by the spec.
JsrSimpleStepBuilder(StepBuilder) - 类 的构造器org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
JsrSplitParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parses a <split /> element as defined in JSR-352.
JsrSplitParser(String) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
 
JsrSplitState - org.springframework.batch.core.jsr.job.flow.support.state中的类
JSR-352 states that artifacts cannot set the ExitStatus from within a split for a job.
JsrSplitState(Collection<Flow>, String) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrSplitState
 
JsrStepContext - org.springframework.batch.core.jsr中的类
Wrapper class to provide the StepContext functionality as specified in JSR-352.
JsrStepContext(StepExecution, Properties) - 类 的构造器org.springframework.batch.core.jsr.JsrStepContext
 
JsrStepContextFactoryBean - org.springframework.batch.core.jsr中的类
FactoryBean implementation used to create StepContext instances within the step scope.
JsrStepContextFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
JsrStepExecution - org.springframework.batch.core.jsr中的类
Implementation of the JsrStepExecution as defined in JSR-352.
JsrStepExecution(StepExecution) - 类 的构造器org.springframework.batch.core.jsr.JsrStepExecution
 
JsrStepExecutionAggregator - org.springframework.batch.core.jsr.partition.support中的类
Aggregates StepExecutions based on the rules outlined in JSR-352.
JsrStepExecutionAggregator() - 类 的构造器org.springframework.batch.core.jsr.partition.support.JsrStepExecutionAggregator
 
JsrStepExecutionSplitter - org.springframework.batch.core.jsr.partition中的类
Provides JSR-352 specific behavior for the splitting of StepExecutions.
JsrStepExecutionSplitter(JobRepository, boolean, String, boolean) - 类 的构造器org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
 
JsrStepHandler - org.springframework.batch.core.jsr.job中的类
Extends SimpleStepHandler to apply JSR-352 specific logic for whether to start a step.
JsrStepHandler(JobRepository, JobExplorer) - 类 的构造器org.springframework.batch.core.jsr.job.JsrStepHandler
 
JsrStepListenerFactoryBean - org.springframework.batch.core.jsr.configuration.xml中的类
 
JsrStepListenerFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
 
JsrStepListenerMetaData - org.springframework.batch.core.jsr中的枚举
Enumeration for the JSR specific StepListener meta data, which ties together the names of methods, their interfaces, and expected arguments.
JsrStepState - org.springframework.batch.core.jsr.job.flow.support.state中的类
Extends StepState to persist what the last step that was executed was (used in Decisions and restarts).
JsrStepState(String, Step) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrStepState
 
JsrStepState(Step) - 类 的构造器org.springframework.batch.core.jsr.job.flow.support.state.JsrStepState
 
JsrTestUtils - org.springframework.batch.test中的类
Provides testing utilities to execute JSR-352 jobs and block until they are complete (since all JSR-352 based jobs are executed asynchronously).
JsrXmlApplicationContext - org.springframework.batch.core.jsr.configuration.xml中的类
GenericApplicationContext implementation providing JSR-352 related context operations.
JsrXmlApplicationContext() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Create a new context instance with no job parameters.
JsrXmlApplicationContext(Properties) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Create a new context instance using the provided Properties representing job parameters when pre-processing the job definition document.
jumpToItem(int) - 类 中的方法org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
jumpToItem(int) - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
 
jumpToItem(int) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Use ResultSet.absolute(int) if possible, otherwise scroll by calling ResultSet.next().
jumpToItem(int) - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
 
jumpToItem(int) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
Wind forward through the result set to the item requested.
jumpToItem(int) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
 
jumpToItem(int) - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Move to the given item index.
jumpToItem(int) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
jumpToItem(ScrollableResults, int, int) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Scroll through the results up to the item specified.
JVM_EXITCODE_COMPLETED - 接口 中的静态变量org.springframework.batch.core.launch.support.ExitCodeMapper
 
JVM_EXITCODE_GENERIC_ERROR - 接口 中的静态变量org.springframework.batch.core.launch.support.ExitCodeMapper
 
JVM_EXITCODE_JOB_ERROR - 接口 中的静态变量org.springframework.batch.core.launch.support.ExitCodeMapper
 
JvmSystemExiter - org.springframework.batch.core.launch.support中的类
Implementation of the SystemExiter interface that calls the standards System.exit method.
JvmSystemExiter() - 类 的构造器org.springframework.batch.core.launch.support.JvmSystemExiter
 

K

keyGenerator(KeyGenerator) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the key generator for identifying retried items.
keyGenerator(KeyGenerator) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
KeyGenerator - org.springframework.batch.core.step.item中的接口
Interface for defining keys to uniquely identify items.
KeyValueItemWriter<K,​V> - org.springframework.batch.item中的类
A base class to implement any ItemWriter that writes to a key value store using a Converter to derive a key from an item
KeyValueItemWriter() - 类 的构造器org.springframework.batch.item.KeyValueItemWriter
 

L

language(String) - 类 中的方法org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Establishes the language of the script.
LAST_NAME_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
LastModifiedResourceComparator - org.springframework.batch.support中的类
Comparator to sort resources by the file last modified time.
LastModifiedResourceComparator() - 类 的构造器org.springframework.batch.support.LastModifiedResourceComparator
 
launch(JobLaunchRequest) - 类 中的方法org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
launch(JobLaunchRequest) - 接口 中的方法org.springframework.batch.integration.launch.JobLaunchRequestHandler
 
launcher(JobLauncher) - 类 中的方法org.springframework.batch.core.step.builder.JobStepBuilder
Add a job launcher.
launchJob() - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Launch the entire job, including all steps.
launchJob() - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Launch the entire job, including all steps.
launchJob(JobParameters) - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Launch the entire job, including all steps
launchJob(JobParameters) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Launch the entire job, including all steps
launchStep(String) - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Launch just the specified step in the job.
launchStep(String) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(String, JobParameters) - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Launch just the specified step in the job.
launchStep(String, JobParameters) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(String, JobParameters, ExecutionContext) - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Launch just the specified step in the job.
launchStep(String, JobParameters, ExecutionContext) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(String, ExecutionContext) - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
Launch just the specified step in the job.
launchStep(String, ExecutionContext) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(Step) - 类 中的方法org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
launchStep(Step, JobParameters) - 类 中的方法org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
launchStep(Step, JobParameters, ExecutionContext) - 类 中的方法org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
launchStep(Step, ExecutionContext) - 类 中的方法org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
LdifReader - org.springframework.batch.item.ldif中的类
The LdifReader is an adaptation of the FlatFileItemReader built around an LdifParser.
LdifReader() - 类 的构造器org.springframework.batch.item.ldif.LdifReader
 
LdifReaderBuilder - org.springframework.batch.item.ldif.builder中的类
Creates a fully qualified LdifReader.
LdifReaderBuilder() - 类 的构造器org.springframework.batch.item.ldif.builder.LdifReaderBuilder
 
LEFT - org.springframework.batch.item.file.transform.Alignment
 
LimitCheckingItemSkipPolicy - org.springframework.batch.core.step.skip中的类
SkipPolicy that determines whether or not reading should continue based upon how many items have been skipped.
LimitCheckingItemSkipPolicy() - 类 的构造器org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Convenience constructor that assumes all exception types are fatal.
LimitCheckingItemSkipPolicy(int, Map<Class<? extends Throwable>, Boolean>) - 类 的构造器org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LimitCheckingItemSkipPolicy(int, Classifier<Throwable, Boolean>) - 类 的构造器org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LimitDecider - org.springframework.batch.sample.loop中的类
This decider will return "CONTINUE" until the limit it reached, at which point it will return "COMPLETE".
LimitDecider() - 类 的构造器org.springframework.batch.sample.loop.LimitDecider
 
LINE_ID_BILLING_ADDR - 类 中的静态变量org.springframework.batch.sample.domain.order.Address
 
LINE_ID_BILLING_INFO - 类 中的静态变量org.springframework.batch.sample.domain.order.BillingInfo
 
LINE_ID_BUSINESS_CUST - 类 中的静态变量org.springframework.batch.sample.domain.order.Customer
 
LINE_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
LINE_ID_FOOTER - 类 中的静态变量org.springframework.batch.sample.domain.order.Order
 
LINE_ID_HEADER - 类 中的静态变量org.springframework.batch.sample.domain.order.Order
 
LINE_ID_ITEM - 类 中的静态变量org.springframework.batch.sample.domain.order.LineItem
 
LINE_ID_NON_BUSINESS_CUST - 类 中的静态变量org.springframework.batch.sample.domain.order.Customer
 
LINE_ID_SHIPPING_ADDR - 类 中的静态变量org.springframework.batch.sample.domain.order.Address
 
LINE_ID_SHIPPING_INFO - 类 中的静态变量org.springframework.batch.sample.domain.order.ShippingInfo
 
lineAggregator - 类 中的变量org.springframework.batch.item.file.FlatFileItemWriter
 
lineAggregator(LineAggregator<T>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Line aggregator used to build the String version of each item.
LineAggregator<T> - org.springframework.batch.item.file.transform中的接口
Interface used to create string representing object.
LineCallbackHandler - org.springframework.batch.item.file中的接口
Callback interface for handling a line from file.
LineItem - org.springframework.batch.sample.domain.order.internal.xml中的类
An XML line-item.
LineItem - org.springframework.batch.sample.domain.order中的类
 
LineItem() - 类 的构造器org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
LineItem() - 类 的构造器org.springframework.batch.sample.domain.order.LineItem
 
LineItemFieldExtractor - org.springframework.batch.sample.domain.order.internal.extractor中的类
 
LineItemFieldExtractor() - 类 的构造器org.springframework.batch.sample.domain.order.internal.extractor.LineItemFieldExtractor
 
lineMapper(LineMapper<T>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A LineMapper implementation to be used.
LineMapper<T> - org.springframework.batch.item.file中的接口
Interface for mapping lines (strings) to domain objects typically used to map lines read from a file to domain objects on a per line basis.
lineSeparator - 类 中的变量org.springframework.batch.item.support.AbstractFileItemWriter
 
lineSeparator(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
String used to separate lines in output.
lineSeparator(String) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
String used to separate lines in output.
linesToSkip(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The number of lines to skip at the beginning of reading the file.
lineTokenizer(LineTokenizer) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A LineTokenizer implementation to be used.
LineTokenizer - org.springframework.batch.item.file.transform中的接口
Interface that is used by framework to split string obtained typically from a file into tokens.
ListableJobLocator - org.springframework.batch.core.configuration中的接口
A listable extension of JobLocator.
listener(Object) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Registers objects using the annotation based listener configuration.
listener(Object) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Registers objects using the annotation based listener configuration.
listener(Object) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Registers objects using the annotation based listener configuration.
listener(Object) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
Registers objects using the annotation based listener configuration.
listener(Object) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(Object) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
listener(Object) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
listener(ChunkListener) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a chunk listener.
listener(ChunkListener) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(ChunkListener) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(ItemProcessListener<? super I, ? super O>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item processor listener.
listener(ItemReadListener<? super I>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item reader listener.
listener(ItemReadListener<? super I>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(ItemWriteListener<? super O>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item writer listener.
listener(ItemWriteListener<? super O>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(JobExecutionListener) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
Register a job execution listener.
listener(RetryListener) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(SkipListener<? super I, ? super O>) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a skip listener.
listener(SkipListener<? super I, ? super O>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(StepExecutionListener) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
listener(StepExecutionListener) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
listener(StepExecutionListener) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
listener(StepExecutionListener) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
listener(RetryListener) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a retry listener.
listener(RetryListener) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
ListenerMetaData - org.springframework.batch.core.listener中的接口
A common interface for listener meta data enumerations.
ListenerParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parses the various listeners defined in JSR-352.
ListenerParser(Class<?>, String) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
ListItemReader<T> - org.springframework.batch.item.support中的类
An ItemReader that pulls data from a list.
ListItemReader(List<T>) - 类 的构造器org.springframework.batch.item.support.ListItemReader
 
ListItemWriter<T> - org.springframework.batch.item.support中的类
 
ListItemWriter() - 类 的构造器org.springframework.batch.item.support.ListItemWriter
 
ListPreparedStatementSetter - org.springframework.batch.item.database.support中的类
Implementation of the PreparedStatementSetter interface that accepts a list of values to be set on a PreparedStatement.
ListPreparedStatementSetter() - 类 的构造器org.springframework.batch.item.database.support.ListPreparedStatementSetter
 
ListPreparedStatementSetter(List<?>) - 类 的构造器org.springframework.batch.item.database.support.ListPreparedStatementSetter
 
load(ApplicationContextFactory) - 类 中的方法org.springframework.batch.core.configuration.support.DefaultJobLoader
 
load(ApplicationContextFactory) - 接口 中的方法org.springframework.batch.core.configuration.support.JobLoader
Load an application context and register all the jobs.
load(Resource...) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Load bean definitions from the given XML resources.
loadResource(String) - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
loadResource(String) - 接口 中的方法org.springframework.batch.sample.launch.JobLoader
 
locale(Locale) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the locale.
log - 类 中的变量org.springframework.batch.item.database.AbstractCursorItemReader
Logger available to subclasses
log(CustomerUpdate) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
log(CustomerUpdate) - 接口 中的方法org.springframework.batch.sample.domain.trade.InvalidCustomerLogger
 
LOG - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
LogAdvice - org.springframework.batch.sample.common中的类
Wraps calls for 'Processing' methods which output a single Object to write the string representation of the object to the log.
LogAdvice() - 类 的构造器org.springframework.batch.sample.common.LogAdvice
 
logger - 类 中的静态变量org.springframework.batch.core.job.AbstractJob
 
logger - 类 中的变量org.springframework.batch.core.job.builder.JobBuilderHelper
 
logger - 类 中的变量org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
logger - 类 中的静态变量org.springframework.batch.core.launch.support.CommandLineJobRunner
 
logger - 类 中的静态变量org.springframework.batch.core.launch.support.SimpleJobLauncher
 
logger - 类 中的变量org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
logger - 类 中的静态变量org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
logger - 类 中的变量org.springframework.batch.core.step.builder.StepBuilderHelper
 
logger - 类 中的变量org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
logger - 类 中的静态变量org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
logger - 类 中的变量org.springframework.batch.core.step.item.SimpleChunkProvider
 
logger - 类 中的静态变量org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
logger - 类 中的静态变量org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
logger - 类 中的变量org.springframework.batch.core.test.timeout.LoggingItemWriter
 
logger - 类 中的变量org.springframework.batch.item.data.AbstractNeo4jItemReader
 
logger - 类 中的静态变量org.springframework.batch.item.data.Neo4jItemWriter
 
logger - 类 中的变量org.springframework.batch.item.data.RepositoryItemReader
 
logger - 类 中的静态变量org.springframework.batch.item.data.RepositoryItemWriter
 
logger - 类 中的变量org.springframework.batch.item.database.AbstractPagingItemReader
 
logger - 类 中的静态变量org.springframework.batch.item.database.HibernateItemWriter
 
logger - 类 中的静态变量org.springframework.batch.item.database.JdbcBatchItemWriter
 
logger - 类 中的静态变量org.springframework.batch.item.database.JpaItemWriter
 
logger - 类 中的变量org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
 
logger - 类 中的变量org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
 
logger - 类 中的变量org.springframework.batch.item.jms.JmsItemReader
 
logger - 类 中的变量org.springframework.batch.item.jms.JmsItemWriter
 
logger - 类 中的变量org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
 
logger - 类 中的静态变量org.springframework.batch.item.support.AbstractFileItemWriter
 
logger - 类 中的变量org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
 
logger - 类 中的变量org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
logger - 类 中的变量org.springframework.batch.repeat.support.RepeatTemplate
 
logger - 类 中的变量org.springframework.batch.test.AbstractJobTests
已过时。
Logger
logger - 类 中的变量org.springframework.batch.test.JobLauncherTestUtils
Logger
logger - 类 中的变量org.springframework.batch.test.StepRunner
Logger
LoggingItemWriter<T> - org.springframework.batch.core.test.timeout中的类
 
LoggingItemWriter() - 类 的构造器org.springframework.batch.core.test.timeout.LoggingItemWriter
 
LogOrRethrowExceptionHandler - org.springframework.batch.repeat.exception中的类
Implementation of ExceptionHandler based on an Classifier.
LogOrRethrowExceptionHandler() - 类 的构造器org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
 
LogOrRethrowExceptionHandler.Level - org.springframework.batch.repeat.exception中的枚举
Logging levels for the handler.
LONG - org.springframework.batch.core.JobParameter.ParameterType
 
LONG_TYPE - 类 中的静态变量org.springframework.batch.core.converter.DefaultJobParametersConverter
 

M

mailErrorHandler(MailErrorHandler) - 类 中的方法org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
The handler for failed messages.
MailErrorHandler - org.springframework.batch.item.mail中的接口
This class is used to handle errors that occur when email messages are unable to be sent.
mailSender(MailSender) - 类 中的方法org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
A MailSender to be used to send messages in SimpleMailMessageItemWriter.write(List).
main(String[]) - 类 中的静态方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Launch a batch job using a CommandLineJobRunner.
main(String...) - 类 中的静态方法org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Supply a list of application context locations, starting with the parent context, and followed by the children.
main(String[]) - 类 中的静态方法org.springframework.batch.sample.rabbitmq.amqp.AmqpMessageProducer
 
main(String...) - 类 中的静态方法org.springframework.batch.test.DataSourceInitializer
Main method as convenient entry point.
MapExecutionContextDao - org.springframework.batch.core.repository.dao中的类
In-memory implementation of ExecutionContextDao backed by maps.
MapExecutionContextDao() - 类 的构造器org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.item.file.mapping.ArrayFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Map the FieldSet to an object retrieved from the enclosing Spring context, or to a new instance of the required type if no prototype is available.
mapFieldSet(FieldSet) - 接口 中的方法org.springframework.batch.item.file.mapping.FieldSetMapper
Method used to map data obtained from a FieldSet into an object.
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.football.internal.GameFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.football.internal.PlayerFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Build an AggregateItem based on matching the first column in the input FieldSet to check for begin and end delimiters.
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
mapFieldSet(FieldSet) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
MapJobExecutionDao - org.springframework.batch.core.repository.dao中的类
In-memory implementation of JobExecutionDao.
MapJobExecutionDao() - 类 的构造器org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
MapJobExplorerFactoryBean - org.springframework.batch.core.explore.support中的类
A FactoryBean that automates the creation of a SimpleJobExplorer using in-memory DAO implementations.
MapJobExplorerFactoryBean() - 类 的构造器org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Create a factory with no MapJobRepositoryFactoryBean.
MapJobExplorerFactoryBean(MapJobRepositoryFactoryBean) - 类 的构造器org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Create an instance with the provided MapJobRepositoryFactoryBean as a source of Dao instances.
MapJobInstanceDao - org.springframework.batch.core.repository.dao中的类
In-memory implementation of JobInstanceDao.
MapJobInstanceDao() - 类 的构造器org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
MapJobRegistry - org.springframework.batch.core.configuration.support中的类
Simple, thread-safe, map-based implementation of JobRegistry.
MapJobRegistry() - 类 的构造器org.springframework.batch.core.configuration.support.MapJobRegistry
 
MapJobRepositoryFactoryBean - org.springframework.batch.core.repository.support中的类
A FactoryBean that automates the creation of a SimpleJobRepository using non-persistent in-memory DAO implementations.
MapJobRepositoryFactoryBean() - 类 的构造器org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Create a new instance with a ResourcelessTransactionManager.
MapJobRepositoryFactoryBean(PlatformTransactionManager) - 类 的构造器org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Create a new instance with the provided transaction manager.
mapLine(String, int) - 接口 中的方法org.springframework.batch.item.file.LineMapper
Implementations must implement this method to map the provided line to the parameter type T.
mapLine(String, int) - 类 中的方法org.springframework.batch.item.file.mapping.DefaultLineMapper
 
mapLine(String, int) - 类 中的方法org.springframework.batch.item.file.mapping.JsonLineMapper
Interpret the line as a Json object and create a Map from it.
mapLine(String, int) - 类 中的方法org.springframework.batch.item.file.mapping.PassThroughLineMapper
 
mapLine(String, int) - 类 中的方法org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
MappingLdifReader<T> - org.springframework.batch.item.ldif中的类
The MappingLdifReader is an adaptation of the FlatFileItemReader built around an LdifParser.
MappingLdifReader() - 类 的构造器org.springframework.batch.item.ldif.MappingLdifReader
 
MappingLdifReaderBuilder<T> - org.springframework.batch.item.ldif.builder中的类
Creates a fully qualified MappingLdifReader.
MappingLdifReaderBuilder() - 类 的构造器org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
 
mapRecord(LdapAttributes) - 接口 中的方法org.springframework.batch.item.ldif.RecordMapper
Maps an LdapAttributes object to the specified type.
mapResult(Object) - 类 中的方法org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
If the result is an ExitStatus already just return that, otherwise return ExitStatus.COMPLETED.
mapRow(ResultSet, int) - 类 中的方法org.springframework.batch.sample.domain.football.internal.PlayerSummaryMapper
 
mapRow(ResultSet, int) - 类 中的方法org.springframework.batch.sample.domain.football.internal.PlayerSummaryRowMapper
 
mapRow(ResultSet, int) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
mapRow(ResultSet, int) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
mapRow(ResultSet, int) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
MapStepExecutionDao - org.springframework.batch.core.repository.dao中的类
In-memory implementation of StepExecutionDao.
MapStepExecutionDao() - 类 的构造器org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
MapStepRegistry - org.springframework.batch.core.configuration.support中的类
Simple map-based implementation of StepRegistry.
MapStepRegistry() - 类 的构造器org.springframework.batch.core.configuration.support.MapStepRegistry
 
markFragmentProcessed() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
Finishes reading the fragment in case the fragment was processed without being read until the end.
markFragmentProcessed() - 接口 中的方法org.springframework.batch.item.xml.stax.FragmentEventReader
Tells the event reader the current fragment has been processed.
markStartFragment() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
markStartFragment() - 接口 中的方法org.springframework.batch.item.xml.stax.FragmentEventReader
Tells the event reader its cursor position is exactly before the fragment.
marshal(T) - 类 中的方法org.springframework.batch.item.json.GsonJsonObjectMarshaller
 
marshal(T) - 类 中的方法org.springframework.batch.item.json.JacksonJsonObjectMarshaller
 
marshal(T) - 接口 中的方法org.springframework.batch.item.json.JsonObjectMarshaller
Marshal an object into a json representation.
marshaller(Marshaller) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The Marshaller implementation responsible for the serialization of the items to XML.
MasterConfiguration - org.springframework.batch.sample.remotechunking中的类
This configuration class is for the master side of the remote chunking sample.
MasterConfiguration - org.springframework.batch.sample.remotepartitioning.aggregating中的类
This configuration class is for the master side of the remote partitioning sample.
MasterConfiguration - org.springframework.batch.sample.remotepartitioning.polling中的类
This configuration class is for the master side of the remote partitioning sample.
MasterConfiguration() - 类 的构造器org.springframework.batch.sample.remotechunking.MasterConfiguration
 
MasterConfiguration(JobBuilderFactory, RemotePartitioningMasterStepBuilderFactory) - 类 的构造器org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
MasterConfiguration(JobBuilderFactory, RemotePartitioningMasterStepBuilderFactory) - 类 的构造器org.springframework.batch.sample.remotepartitioning.polling.MasterConfiguration
 
masterStep() - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
masterStep() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
masterStep() - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.MasterConfiguration
 
match(String) - 枚举 中的静态方法org.springframework.batch.core.BatchStatus
Find a BatchStatus that matches the beginning of the given value.
match(String) - 类 中的方法org.springframework.batch.support.PatternMatcher
This method takes a String key and a map from Strings to values of any type.
match(String, String) - 类 中的静态方法org.springframework.batch.support.PatternMatcher
Lifted from AntPathMatcher in Spring Core.
matches(String) - 类 中的方法org.springframework.batch.core.job.flow.support.StateTransition
Check if the provided status matches the pattern, signalling that the next State should be executed.
matchStatement(String) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
An optional match fragment of the cypher query.
max(BatchStatus, BatchStatus) - 枚举 中的静态方法org.springframework.batch.core.BatchStatus
 
maximumLength(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the maximum length of the formatted string.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Configure the max number of items to be read.
maxRows(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The max number of rows the ResultSet can contain
maxRows(int) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The max number of rows the ResultSet can contain
MaxValueFlowExecutionAggregator - org.springframework.batch.core.job.flow.support.state中的类
Implementation of the FlowExecutionAggregator interface that aggregates FlowExecutionStatus', using the status with the high precedence as the aggregate status.
MaxValueFlowExecutionAggregator() - 类 的构造器org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
 
maxWaitTimeouts(int) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
MessageChannelPartitionHandler - org.springframework.batch.integration.partition中的类
A PartitionHandler that uses MessageChannel instances to send instructions to remote workers and receive their responses.
MessageChannelPartitionHandler() - 类 的构造器org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
MessageProcessor - org.springframework.batch.sample.rabbitmq.processor中的类
Simple ItemProcessor implementation to append a "processed on" Date to a received message.
MessageProcessor() - 类 的构造器org.springframework.batch.sample.rabbitmq.processor.MessageProcessor
 
MessageSourcePollerInterceptor - org.springframework.batch.integration.chunk中的类
A ChannelInterceptor that turns a pollable channel into a "pass-thru channel": if a client calls receive() on the channel it will delegate to a MessageSource to pull the message directly from an external source.
MessageSourcePollerInterceptor() - 类 的构造器org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Convenient default constructor for configuration purposes.
MessageSourcePollerInterceptor(MessageSource<?>) - 类 的构造器org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
 
messagingTemplate(MessagingTemplate) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Set the MessagingTemplate to use to send data to workers.
messagingTemplate(MessagingTemplate) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the MessagingTemplate to use to send data to workers.
MetaDataInstanceFactory - org.springframework.batch.test中的类
Convenience methods for creating test instances of JobExecution, JobInstance and StepExecution.
MetaDataInstanceFactory() - 类 的构造器org.springframework.batch.test.MetaDataInstanceFactory
 
MethodInvoker - org.springframework.batch.support中的接口
A strategy interface for invoking a method.
MethodInvokerMethodInterceptor - org.springframework.batch.core.listener中的类
MethodInterceptor that, given a map of method names and MethodInvokers, will execute all methods tied to a particular method name, with the provided arguments.
MethodInvokerMethodInterceptor(Map<String, Set<MethodInvoker>>) - 类 的构造器org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
MethodInvokerMethodInterceptor(Map<String, Set<MethodInvoker>>, boolean) - 类 的构造器org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
MethodInvokerUtils - org.springframework.batch.support中的类
Utility methods for create MethodInvoker instances.
MethodInvokerUtils() - 类 的构造器org.springframework.batch.support.MethodInvokerUtils
 
MethodInvokingTaskletAdapter - org.springframework.batch.core.step.tasklet中的类
A Tasklet that wraps a method in a POJO.
MethodInvokingTaskletAdapter() - 类 的构造器org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
 
methodIs() - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder.RepositoryMethodReference
The proxy returned prevents actual method execution and is only used to gather, information about the method.
methodIs() - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder.RepositoryMethodReference
The proxy returned prevents actual method execution and is only used to gather, information about the method.
methodName(String) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Specifies what method on the repository to call.
methodName(String) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
Specifies what method on the repository to call.
MethodResolver - org.springframework.batch.support中的接口
Strategy interface for detecting a single Method on a Class.
MIDDLE_NAME_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
MimeMessageItemWriter - org.springframework.batch.item.mail.javamail中的类
A simple ItemWriter that can send mail messages.
MimeMessageItemWriter() - 类 的构造器org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
 
minimumLength(int) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the minimum length of the formatted string.
modular() - 注释类型 中的方法org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Indicate whether the configuration is going to be modularized into multiple application contexts.
ModularBatchConfiguration - org.springframework.batch.core.configuration.annotation中的类
Base Configuration class providing common structure for enabling and using Spring Batch.
ModularBatchConfiguration() - 类 的构造器org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
MongoItemReader<T> - org.springframework.batch.item.data中的类
Restartable ItemReader that reads documents from MongoDB via a paging technique.
MongoItemReader() - 类 的构造器org.springframework.batch.item.data.MongoItemReader
 
MongoItemReaderBuilder<T> - org.springframework.batch.item.data.builder中的类
A builder implementation for the MongoItemReader
MongoItemReaderBuilder() - 类 的构造器org.springframework.batch.item.data.builder.MongoItemReaderBuilder
 
MongoItemWriter<T> - org.springframework.batch.item.data中的类
A ItemWriter implementation that writes to a MongoDB store using an implementation of Spring Data's MongoOperations.
MongoItemWriter() - 类 的构造器org.springframework.batch.item.data.MongoItemWriter
 
MongoItemWriterBuilder<T> - org.springframework.batch.item.data.builder中的类
A builder implementation for the MongoItemWriter
MongoItemWriterBuilder() - 类 的构造器org.springframework.batch.item.data.builder.MongoItemWriterBuilder
 
moveCursorToNextFragment(XMLEventReader) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
Responsible for moving the cursor before the StartElement of the fragment root.
MulticasterBatchListener<T,​S> - org.springframework.batch.core.listener中的类
 
MulticasterBatchListener() - 类 的构造器org.springframework.batch.core.listener.MulticasterBatchListener
Initialize the listener instance.
MultiResourceItemReader<T> - org.springframework.batch.item.file中的类
Reads items from multiple resources sequentially - resource list is given by MultiResourceItemReader.setResources(Resource[]), the actual reading is delegated to MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream).
MultiResourceItemReader() - 类 的构造器org.springframework.batch.item.file.MultiResourceItemReader
 
MultiResourceItemReaderBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder implementation for the MultiResourceItemReader.
MultiResourceItemReaderBuilder() - 类 的构造器org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
 
MultiResourceItemWriter<T> - org.springframework.batch.item.file中的类
Wraps a ResourceAwareItemWriterItemStream and creates a new output resource when the count of items written in current resource exceeds MultiResourceItemWriter.setItemCountLimitPerResource(int).
MultiResourceItemWriter() - 类 的构造器org.springframework.batch.item.file.MultiResourceItemWriter
 
MultiResourceItemWriterBuilder<T> - org.springframework.batch.item.file.builder中的类
A builder implementation for the MultiResourceItemWriter.
MultiResourceItemWriterBuilder() - 类 的构造器org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
 
MultiResourcePartitioner - org.springframework.batch.core.partition.support中的类
Implementation of Partitioner that locates multiple resources and associates their file names with execution context keys.
MultiResourcePartitioner() - 类 的构造器org.springframework.batch.core.partition.support.MultiResourcePartitioner
 
MYSQL - org.springframework.batch.support.DatabaseType
 
MySqlPagingQueryProvider - org.springframework.batch.item.database.support中的类
MySQL implementation of a PagingQueryProvider using database specific features.
MySqlPagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 

N

name(String) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
NAME_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
NAME_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
namedParametersJdbcTemplate(NamedParameterJdbcOperations) - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
The NamedParameterJdbcOperations instance to use.
names - 类 中的变量org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
names(String[]) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Names of each of the fields within the fields that are returned in the order they occur within the delimited file.
names(String[]) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
The names of the fields to be parsed from the file.
names(String[]) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
Names of each of the fields within the fields that are returned in the order they occur within the delimited file.
names(String[]) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Names of each of the fields within the fields that are returned in the order they occur within the formatted file.
namespaceMatchesVersion(Element) - 类 中的静态方法org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
Check that the schema location declared in the source file being parsed matches the Spring Batch version.
nativeQuery(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Used to configure a HibernateNativeQueryProvider.
Neo4jItemReader<T> - org.springframework.batch.item.data中的类
Extensions of the AbstractNeo4jItemReader.
Neo4jItemReader() - 类 的构造器org.springframework.batch.item.data.Neo4jItemReader
 
Neo4jItemReaderBuilder<T> - org.springframework.batch.item.data.builder中的类
A builder for the Neo4jItemReader.
Neo4jItemReaderBuilder() - 类 的构造器org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
 
Neo4jItemWriter<T> - org.springframework.batch.item.data中的类
A ItemWriter implementation that writes to a Neo4j database.
Neo4jItemWriter() - 类 的构造器org.springframework.batch.item.data.Neo4jItemWriter
 
Neo4jItemWriterBuilder<T> - org.springframework.batch.item.data.builder中的类
A builder implementation for the Neo4jItemWriter
Neo4jItemWriterBuilder() - 类 的构造器org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
 
NestedRepeatCallback - org.springframework.batch.repeat.callback中的类
Callback that delegates to another callback, via a RepeatOperations instance.
NestedRepeatCallback(RepeatOperations, RepeatCallback) - 类 的构造器org.springframework.batch.repeat.callback.NestedRepeatCallback
Constructor setting mandatory fields.
NeverSkipItemSkipPolicy - org.springframework.batch.core.step.skip中的类
SkipPolicy implementation that always returns false, indicating that an item should not be skipped.
NeverSkipItemSkipPolicy() - 类 的构造器org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
NEW - 类 中的静态变量org.springframework.batch.sample.common.StagingItemWriter
 
next() - 类 中的方法org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
next() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
next(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Go next on successful completion to a subflow.
next(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Transition to the decider on successful completion of the current step.
next(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
Continue with this decider if the previous step was successful.
next(Step) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Transition to the next step on successful completion of the current step.
next(Step) - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
Continue or end a job with this step if the previous step was successful.
NEXT_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
NEXT_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
nextEvent() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
nextState(String, FlowExecutionStatus, StepExecution) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
nextState(String, FlowExecutionStatus, StepExecution) - 类 中的方法org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
NO_SUCH_JOB - 接口 中的静态变量org.springframework.batch.core.launch.support.ExitCodeMapper
 
NonSkippableProcessException - org.springframework.batch.core.step.skip中的异常错误
Fatal exception to be thrown when a process operation could not be skipped.
NonSkippableProcessException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.NonSkippableProcessException
 
NonSkippableReadException - org.springframework.batch.core.step.skip中的异常错误
Fatal exception to be thrown when a read operation could not be skipped.
NonSkippableReadException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.NonSkippableReadException
 
NonSkippableWriteException - org.springframework.batch.core.step.skip中的异常错误
Fatal exception to be thrown when a process operation could not be skipped.
NonSkippableWriteException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.NonSkippableWriteException
 
NonTransientFlatFileException - org.springframework.batch.item.file中的异常错误
Exception thrown when errors are encountered with the underlying resource.
NonTransientFlatFileException(String, String) - 异常错误 的构造器org.springframework.batch.item.file.NonTransientFlatFileException
 
NonTransientFlatFileException(String, String, int) - 异常错误 的构造器org.springframework.batch.item.file.NonTransientFlatFileException
 
NonTransientFlatFileException(String, Throwable, String, int) - 异常错误 的构造器org.springframework.batch.item.file.NonTransientFlatFileException
 
NonTransientResourceException - org.springframework.batch.item中的异常错误
Exception indicating that an error has been encountered doing I/O from a reader, and the exception should be considered fatal.
NonTransientResourceException(String) - 异常错误 的构造器org.springframework.batch.item.NonTransientResourceException
Create a new NonTransientResourceException based on a message.
NonTransientResourceException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.NonTransientResourceException
Create a new NonTransientResourceException based on a message and another exception.
NOOP - 类 中的静态变量org.springframework.batch.core.ExitStatus
Convenient constant value representing job that did no processing (e.g.
noRetry(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly ask for an exception (and subclasses) to be excluded from retry.
noRetry(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
noRollback(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Mark this exception as ignorable during item read or processing operations.
noRollback(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
noSkip(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly prevent certain exceptions (and subclasses) from being skipped.
noSkip(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
NoStartEndDocumentStreamWriter - org.springframework.batch.item.xml.stax中的类
Delegating XMLEventWriter, which ignores start and end document events, but passes through everything else.
NoStartEndDocumentStreamWriter(XMLEventWriter) - 类 的构造器org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
NoSuchJobException - org.springframework.batch.core.launch中的异常错误
Checked exception to indicate that a required Job is not available.
NoSuchJobException(String) - 异常错误 的构造器org.springframework.batch.core.launch.NoSuchJobException
Create an exception with the given message.
NoSuchJobException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.launch.NoSuchJobException
 
NoSuchJobExecutionException - org.springframework.batch.core.launch中的异常错误
Checked exception to indicate that a required JobExecution is not available.
NoSuchJobExecutionException(String) - 异常错误 的构造器org.springframework.batch.core.launch.NoSuchJobExecutionException
Create an exception with the given message.
NoSuchJobExecutionException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.launch.NoSuchJobExecutionException
 
NoSuchJobInstanceException - org.springframework.batch.core.launch中的异常错误
Exception that signals that the user requested an operation on a non-existent JobInstance.
NoSuchJobInstanceException(String) - 异常错误 的构造器org.springframework.batch.core.launch.NoSuchJobInstanceException
Create an exception with the given message.
NoSuchJobInstanceException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.launch.NoSuchJobInstanceException
 
NoSuchObjectException - org.springframework.batch.core.repository.dao中的异常错误
This exception identifies that a batch domain object is invalid, which is generally caused by an invalid ID.
NoSuchObjectException(String) - 异常错误 的构造器org.springframework.batch.core.repository.dao.NoSuchObjectException
 
NoSuchStepException - org.springframework.batch.core.step中的异常错误
Exception to signal that a step was requested that is unknown or does not exist.
NoSuchStepException(String) - 异常错误 的构造器org.springframework.batch.core.step.NoSuchStepException
Create a new exception instance with the message provided.
NoWorkFoundStepExecutionListener - org.springframework.batch.core.step中的类
Fails the step if no items have been processed ( item count is 0).
NoWorkFoundStepExecutionListener() - 类 的构造器org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
 

O

offset - 类 中的变量org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
on(String) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Start a transition to a new state if the exit status from the previous state matches the pattern given.
on(String) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
Start a transition to a new state if the exit status from the previous state matches the pattern given.
on(String) - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
Branch into a flow conditional on the outcome of the current step.
ON_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
ON_PROCESS_ERROR - org.springframework.batch.core.listener.StepListenerMetaData
 
ON_READ_ERROR - org.springframework.batch.core.listener.StepListenerMetaData
 
ON_SKIP_IN_PROCESS - org.springframework.batch.core.listener.StepListenerMetaData
 
ON_SKIP_IN_READ - org.springframework.batch.core.listener.StepListenerMetaData
 
ON_SKIP_IN_WRITE - org.springframework.batch.core.listener.StepListenerMetaData
 
ON_WRITE_ERROR - org.springframework.batch.core.listener.StepListenerMetaData
 
onApplicationEvent(SimpleMessageApplicationEvent) - 类 中的方法org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
If the event is a SimpleMessageApplicationEvent for open and close we log the event at INFO level and send a JMX notification if we are also an MBean.
onError(JoinPoint, StepExecution, Throwable) - 类 中的方法org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
onError(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
 
onError(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.repeat.listener.RepeatListenerSupport
 
onError(RepeatContext, Throwable) - 接口 中的方法org.springframework.batch.repeat.RepeatListener
Called when a repeat callback fails by throwing an exception.
onError(RepeatContext, Throwable) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
onProcessError(I, Exception) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
onProcessError(T, Exception) - 接口 中的方法org.springframework.batch.core.ItemProcessListener
Called if an exception was thrown from ItemProcessor.process(Object).
onProcessError(T, Exception) - 类 中的方法org.springframework.batch.core.jsr.ItemProcessListenerAdapter
 
onProcessError(T, Exception) - 类 中的方法org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onProcessError(T, Exception) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onProcessError(T, Exception) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
OnProcessError - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called if an exception is thrown by an ItemProcessor

Expected signature: void onProcessError(T item, Exception e)
onReadError(Exception) - 接口 中的方法org.springframework.batch.core.ItemReadListener
Called if an error occurs while trying to read.
onReadError(Exception) - 类 中的方法org.springframework.batch.core.jsr.ItemReadListenerAdapter
 
onReadError(Exception) - 类 中的方法org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onReadError(Exception) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
onReadError(Exception) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onReadError(Exception) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
onReadError(Exception) - 类 中的方法org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
OnReadError - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called if an exception is thrown by an ItemReader

Expected signature: void onReadError(Exception ex)
onRetryProcessException(Object, Exception) - 类 中的方法org.springframework.batch.core.jsr.RetryProcessListenerAdapter
 
onRetryProcessException(Object, Exception) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryProcessListener
 
onRetryProcessException(Object, Exception) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onRetryReadException(Exception) - 类 中的方法org.springframework.batch.core.jsr.RetryReadListenerAdapter
 
onRetryReadException(Exception) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryReadListener
 
onRetryReadException(Exception) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onRetryWriteException(List<Object>, Exception) - 类 中的方法org.springframework.batch.core.jsr.RetryWriteListenerAdapter
 
onRetryWriteException(List<Object>, Exception) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryWriteListener
 
onRetryWriteException(List<Object>, Exception) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInProcess(T, Throwable) - 类 中的方法org.springframework.batch.core.jsr.SkipListenerAdapter
 
onSkipInProcess(T, Throwable) - 类 中的方法org.springframework.batch.core.listener.CompositeSkipListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
onSkipInProcess(T, Throwable) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInProcess(T, Throwable) - 类 中的方法org.springframework.batch.core.listener.SkipListenerSupport
 
onSkipInProcess(T, Throwable) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
onSkipInProcess(T, Throwable) - 接口 中的方法org.springframework.batch.core.SkipListener
This item failed on processing with the given exception, and a skip was called for.
OnSkipInProcess - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called when an item is skipped due to an exception thrown in the ItemProcessor.

Expected signature: void onSkipInProcess(T item, Throwable t)
onSkipInRead(Throwable) - 类 中的方法org.springframework.batch.core.jsr.SkipListenerAdapter
 
onSkipInRead(Throwable) - 类 中的方法org.springframework.batch.core.listener.CompositeSkipListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
onSkipInRead(Throwable) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInRead(Throwable) - 类 中的方法org.springframework.batch.core.listener.SkipListenerSupport
 
onSkipInRead(Throwable) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
onSkipInRead(Throwable) - 接口 中的方法org.springframework.batch.core.SkipListener
Callback for a failure on read that is legal, so is not going to be re-thrown.
OnSkipInRead - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called when an item is skipped due to an exception thrown in the ItemReader

Expected signature: void onSkipInRead(Throwable t)
onSkipInWrite(S, Throwable) - 类 中的方法org.springframework.batch.core.jsr.SkipListenerAdapter
 
onSkipInWrite(S, Throwable) - 类 中的方法org.springframework.batch.core.listener.CompositeSkipListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
onSkipInWrite(S, Throwable) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInWrite(S, Throwable) - 类 中的方法org.springframework.batch.core.listener.SkipListenerSupport
 
onSkipInWrite(S, Throwable) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
onSkipInWrite(S, Throwable) - 接口 中的方法org.springframework.batch.core.SkipListener
This item failed on write with the given exception, and a skip was called for.
OnSkipInWrite - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called when an item is skipped due to an exception thrown in the ItemWriter.

Expected signature: void onSkipInWrite(S item, Throwable t)
onWriteError(Exception, List<? extends Object>) - 类 中的方法org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
onWriteError(Exception, List<? extends O>) - 类 中的方法org.springframework.batch.core.listener.ItemListenerSupport
 
onWriteError(Exception, List<? extends S>) - 接口 中的方法org.springframework.batch.core.ItemWriteListener
Called if an error occurs while trying to write.
onWriteError(Exception, List<? extends S>) - 类 中的方法org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
onWriteError(Exception, List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onWriteError(Exception, List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
 
onWriteError(Exception, List<? extends S>) - 类 中的方法org.springframework.batch.core.listener.StepListenerSupport
 
OnWriteError - org.springframework.batch.core.annotation中的注释类型
Marks a method to be called if an exception is thrown by an ItemWriter

Expected signature: void onWriteError(Exception exception, List<?
open(ExecutionContext) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the beginning of a step, to open or acquire resources.
open(ExecutionContext) - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.integration.async.AsyncItemWriter
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
Figure out which resource to start with in case of restart, open the delegate and restore delegate's position in the resource.
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.file.ResourcesItemReader
 
open(ExecutionContext) - 接口 中的方法org.springframework.batch.item.ItemStream
Open the stream for the provided ExecutionContext.
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.ItemStreamSupport
No-op.
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Initialize the reader.
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to open.
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.SingleItemPeekableItemReader
If the delegate is an ItemStream, just pass the call on, otherwise reset the peek cache.
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.SynchronizedItemStreamReader
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Open the output source
open(ExecutionContext) - 类 中的方法org.springframework.batch.jsr.item.CheckpointSupport
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
open(ExecutionContext) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
open(RepeatContext) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
 
open(RepeatContext) - 类 中的方法org.springframework.batch.repeat.listener.RepeatListenerSupport
 
open(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.RepeatListener
Called once at the start of a complete batch, before any items are processed.
open(RepeatContext) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
open(Resource) - 类 中的方法org.springframework.batch.item.json.GsonJsonObjectReader
 
open(Resource) - 类 中的方法org.springframework.batch.item.json.JacksonJsonObjectReader
 
open(Resource) - 接口 中的方法org.springframework.batch.item.json.JsonObjectReader
Open the Json resource for reading.
openCursor(Connection) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
 
openCursor(Connection) - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
 
openCursor(Connection) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
 
ORACLE - org.springframework.batch.support.DatabaseType
 
OraclePagingQueryProvider - org.springframework.batch.item.database.support中的类
Oracle implementation of a PagingQueryProvider using database specific features.
OraclePagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
Order - org.springframework.batch.sample.domain.order.internal.xml中的类
An XML order.
Order - org.springframework.batch.sample.domain.order中的类
 
Order - org.springframework.batch.item.database中的枚举
The direction of the sort in an ORDER BY clause.
Order() - 类 的构造器org.springframework.batch.sample.domain.order.internal.xml.Order
 
Order() - 类 的构造器org.springframework.batch.sample.domain.order.Order
 
ORDER_DATE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
ORDER_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
orderByStatement(String) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
A list of properties to order the results by.
OrderItemFieldSetMapper - org.springframework.batch.sample.domain.order.internal.mapper中的类
 
OrderItemFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
OrderItemReader - org.springframework.batch.sample.domain.order.internal中的类
 
OrderItemReader() - 类 的构造器org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
OrderLineAggregator - org.springframework.batch.sample.domain.order.internal中的类
Converts Order object to a list of strings.
OrderLineAggregator() - 类 的构造器org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
 
OrderValidator - org.springframework.batch.sample.domain.order.internal.validator中的类
 
OrderValidator() - 类 的构造器org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
org.springframework.batch.container.jms - 程序包 org.springframework.batch.container.jms
 
org.springframework.batch.core - 程序包 org.springframework.batch.core
Core domain context for Spring Batch covering jobs, steps, configuration and execution abstractions.
org.springframework.batch.core.annotation - 程序包 org.springframework.batch.core.annotation
Annotations for java based configuration of listeners.
org.springframework.batch.core.configuration - 程序包 org.springframework.batch.core.configuration
Interfaces for registration and location of job configurations.
org.springframework.batch.core.configuration.annotation - 程序包 org.springframework.batch.core.configuration.annotation
Annotations and builder factories for java based configuration
org.springframework.batch.core.configuration.support - 程序包 org.springframework.batch.core.configuration.support
Specific implementations of configuration concerns.
org.springframework.batch.core.configuration.xml - 程序包 org.springframework.batch.core.configuration.xml
Parsers for XML based configuration
org.springframework.batch.core.converter - 程序包 org.springframework.batch.core.converter
Support classes for implementations of the batch APIs.
org.springframework.batch.core.explore - 程序包 org.springframework.batch.core.explore
Interfaces and related classes to support meta data browsing.
org.springframework.batch.core.explore.support - 程序包 org.springframework.batch.core.explore.support
Specific implementations of explorer concerns.
org.springframework.batch.core.job - 程序包 org.springframework.batch.core.job
Specific implementations of job concerns.
org.springframework.batch.core.job.builder - 程序包 org.springframework.batch.core.job.builder
Job and flow level builders for java based configuration of batch jobs
org.springframework.batch.core.job.flow - 程序包 org.springframework.batch.core.job.flow
Flow related constructs including Flow interface, executors, and related exceptions
org.springframework.batch.core.job.flow.support - 程序包 org.springframework.batch.core.job.flow.support
Basic implementations of flow constructs
org.springframework.batch.core.job.flow.support.state - 程序包 org.springframework.batch.core.job.flow.support.state
States used in defining the underlying Spring Batch state machine
org.springframework.batch.core.jsr - 程序包 org.springframework.batch.core.jsr
Extensions of core batch components to apply JSR-352 specific logic.
org.springframework.batch.core.jsr.configuration.support - 程序包 org.springframework.batch.core.jsr.configuration.support
Extensions of Spring components to support JSR-352 functionality.
org.springframework.batch.core.jsr.configuration.xml - 程序包 org.springframework.batch.core.jsr.configuration.xml
XML parsers for JSR-352 based Job Specification Language (JSL).
org.springframework.batch.core.jsr.job - 程序包 org.springframework.batch.core.jsr.job
JSR-352 specific handler implementations.
org.springframework.batch.core.jsr.job.flow - 程序包 org.springframework.batch.core.jsr.job.flow
JSR-352 specific extensions of Flow constructs (executor and job).
org.springframework.batch.core.jsr.job.flow.support - 程序包 org.springframework.batch.core.jsr.job.flow.support
JSR-352 specific flow extensions.
org.springframework.batch.core.jsr.job.flow.support.state - 程序包 org.springframework.batch.core.jsr.job.flow.support.state
JSR-352 specific states used in flow execution.
org.springframework.batch.core.jsr.launch - 程序包 org.springframework.batch.core.jsr.launch
Implementation of the JSR-352 specific job launching facilities.
org.springframework.batch.core.jsr.launch.support - 程序包 org.springframework.batch.core.jsr.launch.support
 
org.springframework.batch.core.jsr.partition - 程序包 org.springframework.batch.core.jsr.partition
Implementation of JSR-352 specific partitioning extensions.
org.springframework.batch.core.jsr.partition.support - 程序包 org.springframework.batch.core.jsr.partition.support
Support classes for JSR-352 partitioning configuration.
org.springframework.batch.core.jsr.step - 程序包 org.springframework.batch.core.jsr.step
JSR-352 extensions of existing batch Step types.
org.springframework.batch.core.jsr.step.batchlet - 程序包 org.springframework.batch.core.jsr.step.batchlet
Classes for supporting JSR-352's Batchlet.
org.springframework.batch.core.jsr.step.builder - 程序包 org.springframework.batch.core.jsr.step.builder
Extensions to step related builders to implement JSR-352 specific functionality
org.springframework.batch.core.jsr.step.item - 程序包 org.springframework.batch.core.jsr.step.item
JSR-352 specific components for implementing item based processing including fault tolerance.
org.springframework.batch.core.launch - 程序包 org.springframework.batch.core.launch
Interfaces and simple implementations of launch concerns.
org.springframework.batch.core.launch.support - 程序包 org.springframework.batch.core.launch.support
Support classes for use in bootstrap and launch implementations or configurations.
org.springframework.batch.core.listener - 程序包 org.springframework.batch.core.listener
Generic implementations of core batch listener interfaces.
org.springframework.batch.core.partition - 程序包 org.springframework.batch.core.partition
Interfaces for partitioning components.
org.springframework.batch.core.partition.support - 程序包 org.springframework.batch.core.partition.support
Implementation of common partition components.
org.springframework.batch.core.repository - 程序包 org.springframework.batch.core.repository
Interfaces and generic implementations of repository concerns.
org.springframework.batch.core.repository.dao - 程序包 org.springframework.batch.core.repository.dao
Specific implementations of dao concerns.
org.springframework.batch.core.repository.support - 程序包 org.springframework.batch.core.repository.support
Specific implementations of repository concerns.
org.springframework.batch.core.resource - 程序包 org.springframework.batch.core.resource
 
org.springframework.batch.core.scope - 程序包 org.springframework.batch.core.scope
Implementation of Spring Batch specific bean scopes (Job and Step).
org.springframework.batch.core.scope.context - 程序包 org.springframework.batch.core.scope.context
Implementation of the contexts for each of the custom bean scopes in Spring Batch (Job and Step).
org.springframework.batch.core.step - 程序包 org.springframework.batch.core.step
Specific implementations of step concerns.
org.springframework.batch.core.step.builder - 程序包 org.springframework.batch.core.step.builder
Step level builders for java based job configuration.
org.springframework.batch.core.step.factory - 程序包 org.springframework.batch.core.step.factory
Factories for step level components.
org.springframework.batch.core.step.item - 程序包 org.springframework.batch.core.step.item
Specific implementations of step concerns for item-oriented approach.
org.springframework.batch.core.step.job - 程序包 org.springframework.batch.core.step.job
JobStep and related components.
org.springframework.batch.core.step.skip - 程序包 org.springframework.batch.core.step.skip
Specific implementations of skip concerns for items in a step.
org.springframework.batch.core.step.tasklet - 程序包 org.springframework.batch.core.step.tasklet
Interfaces and generic implementations of tasklet concerns.
org.springframework.batch.core.test.football - 程序包 org.springframework.batch.core.test.football
 
org.springframework.batch.core.test.timeout - 程序包 org.springframework.batch.core.test.timeout
 
org.springframework.batch.integration.async - 程序包 org.springframework.batch.integration.async
Components for executing item processing asynchronously and writing the results when processing is complete.
org.springframework.batch.integration.chunk - 程序包 org.springframework.batch.integration.chunk
Components for remote chunking.
org.springframework.batch.integration.config.annotation - 程序包 org.springframework.batch.integration.config.annotation
APIs for the configuration of Spring Integration components through annotations.
org.springframework.batch.integration.config.xml - 程序包 org.springframework.batch.integration.config.xml
APIs for the configuration of Spring Integration components through XML.
org.springframework.batch.integration.launch - 程序包 org.springframework.batch.integration.launch
Message based job launching components.
org.springframework.batch.integration.partition - 程序包 org.springframework.batch.integration.partition
Remote partitioning components.
org.springframework.batch.integration.step - 程序包 org.springframework.batch.integration.step
Support classes related to steps when used with Spring Integration.
org.springframework.batch.item - 程序包 org.springframework.batch.item
Infrastructure interfaces and primary dependencies for item concerns.
org.springframework.batch.item.adapter - 程序包 org.springframework.batch.item.adapter
Adapters for Plain Old Java Objects.
org.springframework.batch.item.amqp - 程序包 org.springframework.batch.item.amqp
AMQP related batch components.
org.springframework.batch.item.amqp.builder - 程序包 org.springframework.batch.item.amqp.builder
Builders for AMQP item reader and writer.
org.springframework.batch.item.data - 程序包 org.springframework.batch.item.data
Spring Data related readers and writers.
org.springframework.batch.item.data.builder - 程序包 org.springframework.batch.item.data.builder
Builders for Spring Data item readers and writers.
org.springframework.batch.item.database - 程序包 org.springframework.batch.item.database
Infrastructure implementations of database based item readers and writers.
org.springframework.batch.item.database.builder - 程序包 org.springframework.batch.item.database.builder
Builders for database item readers and writers.
org.springframework.batch.item.database.orm - 程序包 org.springframework.batch.item.database.orm
Support classes for components using various ORM related technologies.
org.springframework.batch.item.database.support - 程序包 org.springframework.batch.item.database.support
Support classes for database specific semantics.
org.springframework.batch.item.file - 程序包 org.springframework.batch.item.file
Infrastructure implementations of io file concerns.
org.springframework.batch.item.file.builder - 程序包 org.springframework.batch.item.file.builder
Builders for file item readers and writers.
org.springframework.batch.item.file.mapping - 程序包 org.springframework.batch.item.file.mapping
Infrastructure implementations of io file support mapping concerns.
org.springframework.batch.item.file.separator - 程序包 org.springframework.batch.item.file.separator
Infrastructure implementations of io file support separator concerns.
org.springframework.batch.item.file.transform - 程序包 org.springframework.batch.item.file.transform
Infrastructure implementations of io file support transform concerns.
org.springframework.batch.item.function - 程序包 org.springframework.batch.item.function
Adapters for java.util.function components.
org.springframework.batch.item.jms - 程序包 org.springframework.batch.item.jms
JMS based reader/writer and related components.
org.springframework.batch.item.jms.builder - 程序包 org.springframework.batch.item.jms.builder
Builders for JMS item reader and writer.
org.springframework.batch.item.json - 程序包 org.springframework.batch.item.json
Infrastructure implementations of JSON input and output.
org.springframework.batch.item.json.builder - 程序包 org.springframework.batch.item.json.builder
Builders for JSON item reader and writer.
org.springframework.batch.item.ldif - 程序包 org.springframework.batch.item.ldif
This package contains the classes required for using the LdifParser in Spring LDAP.
org.springframework.batch.item.ldif.builder - 程序包 org.springframework.batch.item.ldif.builder
Builders for LDIF related components.
org.springframework.batch.item.mail - 程序包 org.springframework.batch.item.mail
Java Mail based components.
org.springframework.batch.item.mail.builder - 程序包 org.springframework.batch.item.mail.builder
Builders for JavaMail related components.
org.springframework.batch.item.mail.javamail - 程序包 org.springframework.batch.item.mail.javamail
JavaMail related components.
org.springframework.batch.item.support - 程序包 org.springframework.batch.item.support
Internal support package
org.springframework.batch.item.support.builder - 程序包 org.springframework.batch.item.support.builder
Builders for support classes.
org.springframework.batch.item.util - 程序包 org.springframework.batch.item.util
Infrastructure utility classes.
org.springframework.batch.item.validator - 程序包 org.springframework.batch.item.validator
Infrastructure implementations of item validator concerns.
org.springframework.batch.item.xml - 程序包 org.springframework.batch.item.xml
Infrastructure implementations of xml input and output.
org.springframework.batch.item.xml.builder - 程序包 org.springframework.batch.item.xml.builder
Builders for Stax event item reader and writer.
org.springframework.batch.item.xml.stax - 程序包 org.springframework.batch.item.xml.stax
Item reader and writer based on Stax.
org.springframework.batch.jsr.item - 程序包 org.springframework.batch.jsr.item
Components for adapting JSR item based components to Spring Batch.
org.springframework.batch.jsr.repeat - 程序包 org.springframework.batch.jsr.repeat
APIs for JSR-352 repeat support.
org.springframework.batch.poller - 程序包 org.springframework.batch.poller
APIs for polling support.
org.springframework.batch.repeat - 程序包 org.springframework.batch.repeat
Infrastructure implementations of repeat concerns.
org.springframework.batch.repeat.callback - 程序包 org.springframework.batch.repeat.callback
Infrastructure implementations of repeat callback concerns.
org.springframework.batch.repeat.context - 程序包 org.springframework.batch.repeat.context
Infrastructure implementations of repeat context concerns.
org.springframework.batch.repeat.exception - 程序包 org.springframework.batch.repeat.exception
Infrastructure implementations of repeat exception handler concerns.
org.springframework.batch.repeat.interceptor - 程序包 org.springframework.batch.repeat.interceptor
Infrastructure implementations of repeat aop concerns.
org.springframework.batch.repeat.listener - 程序包 org.springframework.batch.repeat.listener
Infrastructure implementations of repeat interceptor concerns.
org.springframework.batch.repeat.policy - 程序包 org.springframework.batch.repeat.policy
Infrastructure implementations of repeat policy concerns.
org.springframework.batch.repeat.support - 程序包 org.springframework.batch.repeat.support
Infrastructure implementations of repeat support concerns.
org.springframework.batch.sample.common - 程序包 org.springframework.batch.sample.common
 
org.springframework.batch.sample.config - 程序包 org.springframework.batch.sample.config
 
org.springframework.batch.sample.data - 程序包 org.springframework.batch.sample.data
 
org.springframework.batch.sample.domain.football - 程序包 org.springframework.batch.sample.domain.football
 
org.springframework.batch.sample.domain.football.internal - 程序包 org.springframework.batch.sample.domain.football.internal
 
org.springframework.batch.sample.domain.mail - 程序包 org.springframework.batch.sample.domain.mail
 
org.springframework.batch.sample.domain.mail.internal - 程序包 org.springframework.batch.sample.domain.mail.internal
 
org.springframework.batch.sample.domain.multiline - 程序包 org.springframework.batch.sample.domain.multiline
 
org.springframework.batch.sample.domain.order - 程序包 org.springframework.batch.sample.domain.order
 
org.springframework.batch.sample.domain.order.internal - 程序包 org.springframework.batch.sample.domain.order.internal
 
org.springframework.batch.sample.domain.order.internal.extractor - 程序包 org.springframework.batch.sample.domain.order.internal.extractor
 
org.springframework.batch.sample.domain.order.internal.mapper - 程序包 org.springframework.batch.sample.domain.order.internal.mapper
 
org.springframework.batch.sample.domain.order.internal.validator - 程序包 org.springframework.batch.sample.domain.order.internal.validator
 
org.springframework.batch.sample.domain.order.internal.xml - 程序包 org.springframework.batch.sample.domain.order.internal.xml
 
org.springframework.batch.sample.domain.person - 程序包 org.springframework.batch.sample.domain.person
 
org.springframework.batch.sample.domain.person.internal - 程序包 org.springframework.batch.sample.domain.person.internal
 
org.springframework.batch.sample.domain.trade - 程序包 org.springframework.batch.sample.domain.trade
 
org.springframework.batch.sample.domain.trade.internal - 程序包 org.springframework.batch.sample.domain.trade.internal
 
org.springframework.batch.sample.domain.trade.internal.validator - 程序包 org.springframework.batch.sample.domain.trade.internal.validator
 
org.springframework.batch.sample.jmx - 程序包 org.springframework.batch.sample.jmx
 
org.springframework.batch.sample.jsr352 - 程序包 org.springframework.batch.sample.jsr352
 
org.springframework.batch.sample.launch - 程序包 org.springframework.batch.sample.launch
 
org.springframework.batch.sample.loop - 程序包 org.springframework.batch.sample.loop
 
org.springframework.batch.sample.quartz - 程序包 org.springframework.batch.sample.quartz
 
org.springframework.batch.sample.rabbitmq.amqp - 程序包 org.springframework.batch.sample.rabbitmq.amqp
 
org.springframework.batch.sample.rabbitmq.processor - 程序包 org.springframework.batch.sample.rabbitmq.processor
 
org.springframework.batch.sample.remotechunking - 程序包 org.springframework.batch.sample.remotechunking
 
org.springframework.batch.sample.remotepartitioning - 程序包 org.springframework.batch.sample.remotepartitioning
 
org.springframework.batch.sample.remotepartitioning.aggregating - 程序包 org.springframework.batch.sample.remotepartitioning.aggregating
 
org.springframework.batch.sample.remotepartitioning.polling - 程序包 org.springframework.batch.sample.remotepartitioning.polling
 
org.springframework.batch.sample.skip - 程序包 org.springframework.batch.sample.skip
 
org.springframework.batch.sample.support - 程序包 org.springframework.batch.sample.support
 
org.springframework.batch.sample.validation - 程序包 org.springframework.batch.sample.validation
 
org.springframework.batch.sample.validation.domain - 程序包 org.springframework.batch.sample.validation.domain
 
org.springframework.batch.support - 程序包 org.springframework.batch.support
Infrastructure implementations of support concerns.
org.springframework.batch.support.annotation - 程序包 org.springframework.batch.support.annotation
 
org.springframework.batch.support.transaction - 程序包 org.springframework.batch.support.transaction
Infrastructure implementations of support transaction concerns.
org.springframework.batch.test - 程序包 org.springframework.batch.test
Utility classes for batch job/step testing.
org.springframework.batch.test.context - 程序包 org.springframework.batch.test.context
APIs for the configuration of Spring Batch test support.
outboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
outboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
outboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
outboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
outboundFlow(ActiveMQConnectionFactory) - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.MasterConfiguration
 
outputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the output channel on which replies will be sent to the master step.
outputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the output channel on which replies will be sent to the master step.
OutputFileListener - org.springframework.batch.sample.common中的类
 
OutputFileListener() - 类 的构造器org.springframework.batch.sample.common.OutputFileListener
 
OutputFileNameListener - org.springframework.batch.sample.common中的类
 
OutputFileNameListener() - 类 的构造器org.springframework.batch.sample.common.OutputFileNameListener
 
OutputState() - 类 的构造器org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
overwriteOutput(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Indicates if an existing file should be overwritten if found.

P

page - 类 中的变量org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
pageSize - 类 中的变量org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
pageSize - 类 中的变量org.springframework.batch.item.data.builder.MongoItemReaderBuilder
 
pageSize(int) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
The number of items to be read with each page.
pageSize(int) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The number of items to be read with each page.
pageSize(int) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Establish the pageSize for the generated RepositoryItemReader.
pageSize(int) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The number of records to request per page/query.
pageSize(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The number of records to request per page/query.
pageSize(int) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The number of records to request per page/query.
PagingQueryProvider - org.springframework.batch.item.database中的接口
Interface defining the functionality to be provided for generating paging queries for use with Paging Item Readers.
parameters(SqlParameter[]) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
SQL parameters to be set when executing the stored procedure
parametersExtractor(JobParametersExtractor) - 类 中的方法org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job parameters extractor.
parameterValues(List<Object>) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
List of values to be substituted in for each of the parameters in the query.
parameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Optional parameters to be used in the cypher query.
parameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
A map of parameter values to be set on the query.
parameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
A map of parameter values to be set on the query.
parameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
A Map of values to set on the SQL's prepared statement.
parameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
A map of parameter values to be set on the query.
parse(Element, AbstractBeanDefinition, ParserContext, boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.ChunkElementParser
 
parse(Element, AbstractBeanDefinition, ParserContext, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.ChunkParser
 
parse(Element, AbstractBeanDefinition, ParserContext, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.PartitionParser
 
parse(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parse(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.DecisionParser
Parse the decision and turn it into a list of transitions.
parse(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.FlowElementParser
Parse the flow and turn it into a list of transitions.
parse(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.SplitParser
Parse the split and turn it into a list of transitions.
parse(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.StandaloneStepParser
Parse the step and turn it into a list of transitions.
parse(Element, ParserContext) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
 
parse(Element, ParserContext, String) - 类 中的方法org.springframework.batch.core.configuration.xml.ExceptionElementParser
 
parse(Element, ParserContext, String) - 类 中的方法org.springframework.batch.core.configuration.xml.InlineStepParser
Parse the step and turn it into a list of transitions.
parse(Element, ParserContext, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrDecisionParser
 
parse(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepParser
 
parseBatchlet(Element, AbstractBeanDefinition, ParserContext, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.BatchletParser
 
parseBeanElement(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParser
 
ParseException - org.springframework.batch.item中的异常错误
Exception indicating that an error has been encountered parsing IO, typically from a file.
ParseException(String) - 异常错误 的构造器org.springframework.batch.item.ParseException
Create a new ParseException based on a message.
ParseException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.ParseException
Create a new ParseException based on a message and another exception.
parseExpression(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.JsrExpressionParser
Parses the provided expression, applying any transformations needed to evaluate as a SPeL expression.
parseHandler(Element, ParserContext) - 类 中的方法org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
parseInternal(Element, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
parseInternal(Element, ParserContext) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.BatchParser
 
parseInternal(Element, ParserContext) - 类 中的方法org.springframework.batch.integration.config.xml.RemoteChunkingMasterParser
 
parseInternal(Element, ParserContext) - 类 中的方法org.springframework.batch.integration.config.xml.RemoteChunkingSlaveParser
 
parseListenerElement(Element, ParserContext, BeanDefinition) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parseListeners(Element, ParserContext, AbstractBeanDefinition, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
parseListeners(Element, ParserContext, BeanDefinitionBuilder) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
parsePartitionPlan(Element, ParserContext, String, MutablePropertyValues) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.PartitionParser
 
parseProperties(Element) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.PropertyParser
Parses <property> tag values from the provided Element if it contains a <properties /> element.
parseProperty(Element) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.PropertyParser
Parses a <property> tag value from the provided Element.
parseStep(Element, ParserContext, String) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractStepParser
 
parseTasklet(Element, Element, AbstractBeanDefinition, ParserContext, boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.TaskletParser
 
parseTransitionElement(Element, String, BeanDefinition, ParserContext) - 类 中的静态方法org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
partition(int) - 类 中的方法org.springframework.batch.core.partition.support.MultiResourcePartitioner
Assign the filename of each of the injected resources to an ExecutionContext.
partition(int) - 接口 中的方法org.springframework.batch.core.partition.support.Partitioner
Create a set of distinct ExecutionContext instances together with a unique identifier for each one.
partition(int) - 类 中的方法org.springframework.batch.core.partition.support.SimplePartitioner
 
partition(int) - 类 中的方法org.springframework.batch.sample.common.ColumnRangePartitioner
Partition a database table assuming that the data in the column specified are uniformly distributed.
partition(int) - 类 中的方法org.springframework.batch.sample.remotepartitioning.BasicPartitioner
 
PartitionCollectorAdapter - org.springframework.batch.core.jsr.partition中的类
Adapter class used to wrap a PartitionCollector so that it can be consumed as a ChunkListener.
PartitionCollectorAdapter(Queue<Serializable>, PartitionCollector) - 类 的构造器org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
partitioner(String, Partitioner) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
Add a partitioner which can be used to create a StepExecutionSplitter.
partitioner(String, Partitioner) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
partitioner(String, Partitioner) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
partitioner(String, Partitioner) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
partitioner(Step) - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
partitioner(Step) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
partitioner(Step) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
Partitioner - org.springframework.batch.core.partition.support中的接口
Central strategy interface for creating input parameters for a partitioned step in the form of ExecutionContext instances.
partitionHandler(PartitionHandler) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit partition handler that will carry out the work of the partition step.
partitionHandler(PartitionHandler) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
This method will throw a UnsupportedOperationException since the partition handler of the master step will be automatically set to an instance of MessageChannelPartitionHandler.
PartitionHandler - org.springframework.batch.core.partition中的接口
Interface defining the responsibilities of controlling the execution of a partitioned StepExecution.
PartitionNameProvider - org.springframework.batch.core.partition.support中的接口
Optional interface for Partitioner implementations that need to use a custom naming scheme for partitions.
PartitionParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser for the <partition> element as defined by JSR-352.
PartitionParser(String, boolean) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.PartitionParser
 
PartitionPlanState() - 类 的构造器org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
PartitionPlanState(PartitionPlan) - 类 的构造器org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
PartitionStep - org.springframework.batch.core.jsr.step中的类
An extension of the PartitionStep that provides additional semantics required by JSR-352.
PartitionStep - org.springframework.batch.core.partition.support中的类
Implementation of Step which partitions the execution and spreads the load using a PartitionHandler.
PartitionStep() - 类 的构造器org.springframework.batch.core.jsr.step.PartitionStep
 
PartitionStep() - 类 的构造器org.springframework.batch.core.partition.support.PartitionStep
 
PartitionStepBuilder - org.springframework.batch.core.step.builder中的类
Step builder for PartitionStep instances.
PartitionStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.PartitionStepBuilder
Create a new builder initialized with any properties in the parent.
PassThroughFieldExtractor<T> - org.springframework.batch.item.file.transform中的类
FieldExtractor that just returns the original item.
PassThroughFieldExtractor() - 类 的构造器org.springframework.batch.item.file.transform.PassThroughFieldExtractor
 
PassThroughFieldSetMapper - org.springframework.batch.item.file.mapping中的类
Pass through FieldSetMapper useful for passing a FieldSet back directly rather than a mapped object.
PassThroughFieldSetMapper() - 类 的构造器org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
PassThroughItemProcessor<T> - org.springframework.batch.item.support中的类
Simple ItemProcessor that does nothing - simply passes its argument through to the caller.
PassThroughItemProcessor() - 类 的构造器org.springframework.batch.item.support.PassThroughItemProcessor
 
PassThroughLineAggregator<T> - org.springframework.batch.item.file.transform中的类
A LineAggregator implementation that simply calls Object.toString() on the given object
PassThroughLineAggregator() - 类 的构造器org.springframework.batch.item.file.transform.PassThroughLineAggregator
 
PassThroughLineMapper - org.springframework.batch.item.file.mapping中的类
Pass through LineMapper useful for passing the original String back directly rather than a mapped object.
PassThroughLineMapper() - 类 的构造器org.springframework.batch.item.file.mapping.PassThroughLineMapper
 
PatternMatcher<S> - org.springframework.batch.support中的类
 
PatternMatcher(Map<String, S>) - 类 的构造器org.springframework.batch.support.PatternMatcher
Initialize a new PatternMatcher with a map of patterns to values
PatternMatchingCompositeLineMapper<T> - org.springframework.batch.item.file.mapping中的类
A LineMapper implementation that stores a mapping of String patterns to delegate LineTokenizers as well as a mapping of String patterns to delegate FieldSetMappers.
PatternMatchingCompositeLineMapper() - 类 的构造器org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
PatternMatchingCompositeLineTokenizer - org.springframework.batch.item.file.transform中的类
A LineTokenizer implementation that stores a mapping of String patterns to delegate LineTokenizers.
PatternMatchingCompositeLineTokenizer() - 类 的构造器org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
PAYMENT_DESC_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
PAYMENT_TYPE_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
peek() - 接口 中的方法org.springframework.batch.item.PeekableItemReader
Get the next item that would be returned by ItemReader.read(), without affecting the result of ItemReader.read().
peek() - 类 中的方法org.springframework.batch.item.support.SingleItemPeekableItemReader
Peek at the next item, ensuring that if the delegate is an ItemStream the state is stored for the next call to SingleItemPeekableItemReader.update(ExecutionContext).
peek() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
PeekableItemReader<T> - org.springframework.batch.item中的接口
A specialisation of ItemReader that allows the user to look ahead into the stream of items.
persist(StepContribution, Chunk<O>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Responsible for the writing portion of the chunking loop.
persist(StepContribution, Chunk<O>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Adds retry and skip logic to the write phase of the chunk loop.
Person - org.springframework.batch.sample.domain.person中的类
 
Person - org.springframework.batch.sample.validation.domain中的类
 
Person() - 类 的构造器org.springframework.batch.sample.domain.person.Person
 
Person() - 类 的构造器org.springframework.batch.sample.validation.domain.Person
 
Person(int, String) - 类 的构造器org.springframework.batch.sample.validation.domain.Person
 
PersonService - org.springframework.batch.sample.domain.person中的类
Custom class that contains logic that would normally be be contained in ItemReader and ItemWriter.
PersonService() - 类 的构造器org.springframework.batch.sample.domain.person.PersonService
 
PersonWriter - org.springframework.batch.sample.domain.person.internal中的类
 
PersonWriter() - 类 的构造器org.springframework.batch.sample.domain.person.internal.PersonWriter
 
Player - org.springframework.batch.core.test.football中的类
 
Player - org.springframework.batch.sample.domain.football中的类
 
Player() - 类 的构造器org.springframework.batch.core.test.football.Player
 
Player() - 类 的构造器org.springframework.batch.sample.domain.football.Player
 
PlayerDao - org.springframework.batch.core.test.football中的接口
Interface for writing Player objects to arbitrary output.
PlayerDao - org.springframework.batch.sample.domain.football中的接口
Interface for writing Player objects to arbitrary output.
PlayerFieldSetMapper - org.springframework.batch.sample.domain.football.internal中的类
 
PlayerFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.football.internal.PlayerFieldSetMapper
 
PlayerItemWriter - org.springframework.batch.sample.domain.football.internal中的类
 
PlayerItemWriter() - 类 的构造器org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
PlayerSummary - org.springframework.batch.core.test.football中的类
Domain object representing the summary of a given Player's year.
PlayerSummary - org.springframework.batch.sample.domain.football中的类
Domain object representing the summary of a given Player's year.
PlayerSummary() - 类 的构造器org.springframework.batch.core.test.football.PlayerSummary
 
PlayerSummary() - 类 的构造器org.springframework.batch.sample.domain.football.PlayerSummary
 
PlayerSummaryMapper - org.springframework.batch.sample.domain.football.internal中的类
RowMapper used to map a ResultSet to a PlayerSummary
PlayerSummaryMapper() - 类 的构造器org.springframework.batch.sample.domain.football.internal.PlayerSummaryMapper
 
PlayerSummaryRowMapper - org.springframework.batch.sample.domain.football.internal中的类
RowMapper used to map a ResultSet to a PlayerSummary
PlayerSummaryRowMapper() - 类 的构造器org.springframework.batch.sample.domain.football.internal.PlayerSummaryRowMapper
 
poll(Callable<S>) - 类 中的方法org.springframework.batch.poller.DirectPoller
Get a future for a non-null result from the callback.
poll(Callable<T>) - 接口 中的方法org.springframework.batch.poller.Poller
Use the callable provided to poll for a non-null result.
Poller<T> - org.springframework.batch.poller中的接口
Interface for polling a Callable instance provided by the user.
pollInterval(long) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
How often to poll the job repository for the status of the workers.
position() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
Return the byte offset position of the cursor in the output file as a long integer.
POSTGRES - org.springframework.batch.support.DatabaseType
 
PostgresPagingQueryProvider - org.springframework.batch.item.database.support中的类
Postgres implementation of a PagingQueryProvider using database specific features.
PostgresPagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
postProcess(String) - 接口 中的方法org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Give the policy a chance to post-process a complete record, e.g. remove a suffix.
postProcess(String) - 类 中的方法org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Pass the record through.
postProcess(String) - 类 中的方法org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Remove the suffix from the end of the record.
postProcess(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
postProcess(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
 
postProcess(StepContribution, Chunk<T>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProvider
 
postProcess(StepContribution, Chunk<T>) - 接口 中的方法org.springframework.batch.core.step.item.ChunkProvider
 
postProcessAfterInitialization(Object, String) - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
If the bean is an instance of Job then register it.
postProcessAfterInitialization(Object, String) - 类 中的方法org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessAfterInitialization(Object, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
postProcessAfterInitialization(Object, String) - 类 中的方法org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - 类 中的方法org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.ThreadLocalClassloaderBeanPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - 类 中的方法org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
Register this scope with the enclosing BeanFactory.
postProcessBeforeInitialization(Object, String) - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Do nothing.
postProcessBeforeInitialization(Object, String) - 类 中的方法org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeforeInitialization(Object, String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
postProcessBeforeInitialization(Object, String) - 类 中的方法org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
prepareBeanFactory(ConfigurableListableBeanFactory, ConfigurableListableBeanFactory) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Extension point for special subclasses that want to do more complex things with the bean factory prior to refresh.
prepareContext(ConfigurableApplicationContext, ConfigurableApplicationContext) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Extension point for special subclasses that want to do more complex things with the context prior to refresh.
preparedStatementSetter(PreparedStatementSetter) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures the provided PreparedStatementSetter to be used to populate any arguments in the SQL query to be executed for the reader.
preparedStatementSetter(PreparedStatementSetter) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Configures the provided PreparedStatementSetter to be used to populate any arguments in the SQL query to be executed for the reader.
prepareTestInstance(TestContext) - 类 中的方法org.springframework.batch.test.JobScopeTestExecutionListener
Set up a JobExecution as a test context attribute.
prepareTestInstance(TestContext) - 类 中的方法org.springframework.batch.test.StepScopeTestExecutionListener
Set up a StepExecution as a test context attribute.
preProcess(String) - 类 中的方法org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
If we are in an unterminated quote, add a line separator.
preProcess(String) - 接口 中的方法org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Pre-process a record before another line is appended, in the case of a multi-line record.
preProcess(String) - 类 中的方法org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Pass the line through.
preProcessXml(Element) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
preReceive(MessageChannel) - 类 中的方法org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Receive from the MessageSource and send immediately to the input channel, so that the call that we are intercepting always a message to receive.
preSend(Message<?>, MessageChannel) - 类 中的方法org.springframework.batch.integration.async.StepExecutionInterceptor
 
presetSystemExiter(SystemExiter) - 类 中的静态方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Static setter for the SystemExiter so it can be adjusted before dependency injection.
preventRestart() - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
Set a flag to prevent restart an execution of this job even if it has failed.
PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
procedureName(String) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The name of the stored procedure to execute
process() - 类 中的方法org.springframework.batch.sample.jsr352.JsrSampleBatchlet
 
process(I) - 类 中的方法org.springframework.batch.core.test.timeout.SleepingItemProcessor
 
process(I) - 类 中的方法org.springframework.batch.integration.async.AsyncItemProcessor
Transform the input by delegating to the provided item processor.
process(I) - 类 中的方法org.springframework.batch.item.adapter.ItemProcessorAdapter
Invoke the delegate method and return the result.
process(I) - 类 中的方法org.springframework.batch.item.function.FunctionItemProcessor
 
process(I) - 接口 中的方法org.springframework.batch.item.ItemProcessor
Process the provided item, returning a potentially modified or new item for continued processing.
process(I) - 类 中的方法org.springframework.batch.item.support.ClassifierCompositeItemProcessor
Delegates to injected ItemProcessor instances according to the classification by the Classifier.
process(I) - 类 中的方法org.springframework.batch.item.support.CompositeItemProcessor
 
process(I) - 类 中的方法org.springframework.batch.item.support.ScriptItemProcessor
 
process(I) - 类 中的方法org.springframework.batch.jsr.item.ItemProcessorAdapter
 
process(String) - 类 中的方法org.springframework.batch.sample.rabbitmq.processor.MessageProcessor
 
process(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Loops through reading (via JsrChunkProcessor.provide(StepContribution, Chunk) and processing (via JsrChunkProcessor.transform(StepContribution, Object)) until the chunk is complete.
process(StepContribution, Chunk<I>) - 接口 中的方法org.springframework.batch.core.step.item.ChunkProcessor
 
process(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
process(ProcessIndicatorItemWrapper<T>) - 类 中的方法org.springframework.batch.sample.common.StagingItemProcessor
Use the technical identifier to mark the input row as processed and return unwrapped item.
process(User) - 类 中的方法org.springframework.batch.sample.domain.mail.internal.UserMailItemProcessor
 
process(CustomerCredit) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
process(CustomerUpdate) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
process(Trade) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeProcessor
 
process(T) - 类 中的方法org.springframework.batch.item.support.PassThroughItemProcessor
Just returns the item back to the caller.
process(T) - 类 中的方法org.springframework.batch.item.validator.ValidatingItemProcessor
Validate the item and return it unmodified
ProcessIndicatorItemWrapper<T> - org.springframework.batch.sample.common中的类
Item wrapper useful in "process indicator" usecase, where input is marked as processed by the processor/writer.
ProcessIndicatorItemWrapper(long, T) - 类 的构造器org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
processItem(Object) - 类 中的方法org.springframework.batch.sample.jsr352.JsrSampleItemProcessor
 
processor(Function<? super I, ? extends O>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
A Function to be delegated to as an ItemProcessor.
processor(ItemProcessor<? super I, ? extends O>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
An item processor that processes or transforms a stream of items.
processor(ItemProcessor<? super I, ? extends O>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
processorNonTransactional() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Mark the item processor as non-transactional (default is the opposite).
processPerson(String, String) - 类 中的方法org.springframework.batch.sample.domain.person.PersonService
 
properties - 类 中的变量org.springframework.batch.core.step.builder.StepBuilderHelper
 
PropertiesConverter - org.springframework.batch.support中的类
Utility to convert a Properties object to a String and back.
propertiesToString(Properties) - 类 中的静态方法org.springframework.batch.support.PropertiesConverter
Convert Properties object to String.
PropertyExtractingDelegatingItemWriter<T> - org.springframework.batch.item.adapter中的类
Delegates processing to a custom method - extracts property values from item object and uses them as arguments for the delegate method.
PropertyExtractingDelegatingItemWriter() - 类 的构造器org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
PropertyParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser for the <properties /> element defined by JSR-352.
PropertyParser(String, ParserContext, BatchArtifactType) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.PropertyParser
 
PropertyParser(String, ParserContext, BatchArtifactType, String) - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.PropertyParser
 
prototypeBeanName(String) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configures the id of a prototype scoped bean to be used as the item returned by the reader.
provide(StepContribution) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProvider
 
provide(StepContribution) - 接口 中的方法org.springframework.batch.core.step.item.ChunkProvider
 
provide(StepContribution) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
 
provide(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Responsible for the reading portion of the chunking loop.
provide(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Adds retry and skip logic to the reading phase of the chunk loop.
put(String, Object) - 类 中的方法org.springframework.batch.item.ExecutionContext
Add an Object value to the context.
put(ResultHolder) - 类 中的方法org.springframework.batch.repeat.support.ResultHolderResultQueue
 
put(T) - 类 中的方法org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
putDouble(String, double) - 类 中的方法org.springframework.batch.item.ExecutionContext
Add a Double value to the context.
putInt(String, int) - 类 中的方法org.springframework.batch.item.ExecutionContext
Adds an Integer value to the context.
putLong(String, long) - 类 中的方法org.springframework.batch.item.ExecutionContext
Adds a Long value to the context.
putString(String, String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Adds a String value to the context.

Q

QUANTITY_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
QUANTITY_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
QUANTITY_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
query(Query) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Provide a Spring Data Mongo Query.
QUERY - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
queryArguments(Object[]) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures a PreparedStatementSetter that will use the array as the values to be set on the query to be executed for this reader.
queryArguments(Object[], int[]) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures a PreparedStatementSetter that will use the Object [] as the values to be set on the query to be executed for this reader.
queryArguments(List<?>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures a PreparedStatementSetter that will use the List as the values to be set on the query to be executed for this reader.
queryName(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The name of the Hibernate named query to be executed for this reader.
queryName(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The name of the Hibernate named query to be executed for this reader.
queryProvider(HibernateQueryProvider) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
A query provider.
queryProvider(HibernateQueryProvider<T>) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
A query provider.
queryProvider(JpaQueryProvider) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
A query provider.
queryProvider(PagingQueryProvider) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
A PagingQueryProvider to provide the queries required.
queryString(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The HQL query string to execute.
queryString(String) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The HQL query string to execute.
queryString(String) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The HQL query string to execute.
queryTimeout(int) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The time in milliseconds for the query to timeout
queryTimeout(int) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The time in milliseconds for the query to timeout
quoteCharacter(char) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Define the character used to quote fields.

R

Range - org.springframework.batch.item.file.transform中的类
A class to represent ranges.
Range(int) - 类 的构造器org.springframework.batch.item.file.transform.Range
 
Range(int, int) - 类 的构造器org.springframework.batch.item.file.transform.Range
 
RangeArrayPropertyEditor - org.springframework.batch.item.file.transform中的类
Property editor implementation which parses string and creates array of ranges.
RangeArrayPropertyEditor() - 类 的构造器org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
read() - 类 中的方法org.springframework.batch.item.adapter.ItemReaderAdapter
 
read() - 类 中的方法org.springframework.batch.item.amqp.AmqpItemReader
 
read() - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
Reads the next item, jumping to next resource if necessary.
read() - 类 中的方法org.springframework.batch.item.file.ResourcesItemReader
Increments a counter and returns the next Resource instance from the input, or null if none remain.
read() - 接口 中的方法org.springframework.batch.item.ItemReader
Reads a piece of input data and advance to the next one.
read() - 类 中的方法org.springframework.batch.item.jms.JmsItemReader
 
read() - 类 中的方法org.springframework.batch.item.json.GsonJsonObjectReader
 
read() - 类 中的方法org.springframework.batch.item.json.JacksonJsonObjectReader
 
read() - 接口 中的方法org.springframework.batch.item.json.JsonObjectReader
Read the next object in the Json resource if any.
read() - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
read() - 类 中的方法org.springframework.batch.item.support.IteratorItemReader
Implementation of ItemReader.read() that just iterates over the iterator provided.
read() - 类 中的方法org.springframework.batch.item.support.ListItemReader
 
read() - 类 中的方法org.springframework.batch.item.support.SingleItemPeekableItemReader
Get the next item from the delegate (whether or not it has already been peeked at).
read() - 类 中的方法org.springframework.batch.item.support.SynchronizedItemStreamReader
This delegates to the read method of the delegate
read() - 类 中的方法org.springframework.batch.jsr.item.ItemReaderAdapter
 
read() - 类 中的方法org.springframework.batch.sample.common.InfiniteLoopReader
 
read() - 类 中的方法org.springframework.batch.sample.common.StagingItemReader
 
read() - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemReader
Get the next list of records.
read() - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
read() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
read() - 类 中的方法org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
read(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
read(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
readAndTrim(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
Read and trim the String value at 'index'.
readBigDecimal(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value at index 'index'.
readBigDecimal(int, BigDecimal) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(int, BigDecimal) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value at index 'index', returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBigDecimal(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value from column with given 'name.
readBigDecimal(String, BigDecimal) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(String, BigDecimal) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value from column with given 'name, returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBoolean(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(int, String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(int, String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value from column with given 'name'.
readBoolean(String, String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(String, String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value from column with given 'name'.
readByte(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readByte(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'byte' value at index 'index'.
readByte(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readByte(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'byte' value from column with given 'name'.
readChar(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readChar(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'char' value at index 'index'.
readChar(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readChar(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'char' value from column with given 'name'.
readCursor(ResultSet, int) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Read the cursor and map to the type of object this reader should return.
readCursor(ResultSet, int) - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
 
readCursor(ResultSet, int) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
 
readDate(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(int, String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(int, String, Date) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, String, Date) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(int, Date) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, Date) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(String, String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(String, String, Date) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, String, Date) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(String, Date) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, Date) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDouble(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDouble(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'double' value at index 'index'.
readDouble(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDouble(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'double' value from column with given 'name.
reader() - 类 中的方法org.springframework.batch.sample.config.RetrySampleConfiguration
 
reader(ItemReader<? extends I>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
An item reader that provides a stream of items.
reader(ItemReader<? extends I>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
readerIsTransactionalQueue() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets a flag to say that the reader is transactional (usually a queue), which is to say that failed items might be rolled back and re-presented in a subsequent transaction.
readerIsTransactionalQueue() - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
ReaderNotOpenException - org.springframework.batch.item中的异常错误
Exception indicating that an ItemReader needed to be opened before read.
ReaderNotOpenException(String) - 异常错误 的构造器org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message.
ReaderNotOpenException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message and another exception.
readFloat(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readFloat(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'float' value at index 'index'.
readFloat(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readFloat(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'float' value from column with given 'name.
readInt(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value at index 'index'.
readInt(int, int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(int, int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value at index 'index', using the supplied defaultValue if the field value is blank.
readInt(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value from column with given 'name'.
readInt(String, int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(String, int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readItem() - 类 中的方法org.springframework.batch.sample.jsr352.JsrSampleItemReader
 
readLong(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value at index 'index'.
readLong(int, long) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(int, long) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value at index 'index', using the supplied defaultValue if the field value is blank.
readLong(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value from column with given 'name'.
readLong(String, long) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(String, long) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readPage(int, int, int, Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Read a page of data, clearing the existing session (if necessary) first, and creating a new session before executing the query.
readRawString(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readRawString(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the String value at index 'index' including trailing whitespace (don't trim).
readRawString(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readRawString(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the String value from column with given 'name' including trailing whitespace (don't trim).
readShort(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readShort(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'short' value at index 'index'.
readShort(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readShort(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the 'short' value from column with given 'name'.
readString(int) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readString(int) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the String value at index 'index'.
readString(String) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
readString(String) - 接口 中的方法org.springframework.batch.item.file.transform.FieldSet
Read the String value from column with given 'name'.
receiveAndExecute(Object, Session, MessageConsumer) - 接口 中的方法org.springframework.batch.container.jms.BatchMessageListenerContainer.ContainerDelegate
 
receiveAndExecute(Object, Session, MessageConsumer) - 类 中的方法org.springframework.batch.container.jms.BatchMessageListenerContainer
Override base class method to wrap call in advice if provided.
RecordCallbackHandler - org.springframework.batch.item.ldif中的接口
This interface can be used to operate on skipped records during open in the LdifReader and the MappingLdifReader.
recordMapper(RecordMapper<T>) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Setter for object mapper.
RecordMapper<T> - org.springframework.batch.item.ldif中的接口
This interface should be implemented to map LdapAttributes objects to POJOs.
recordSeparatorPolicy(RecordSeparatorPolicy) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure a custom RecordSeparatorPolicy for the reader.
RecordSeparatorPolicy - org.springframework.batch.item.file.separator中的接口
Policy for text file-based input sources to determine the end of a record, e.g. a record might be a single line, or it might be multiple lines terminated by a semicolon.
recordsToSkip(int) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Public setter for the number of lines to skip at the start of a file.
recordsToSkip(int) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Public setter for the number of lines to skip at the start of a file.
recover(Object[], Throwable) - 类 中的方法org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
Send one message per item in the arguments list using the default destination of the jms template.
RecursiveCollectionLineAggregator<T> - org.springframework.batch.item.file.transform中的类
An implementation of LineAggregator that concatenates a collection of items of a common type with the system line separator.
RecursiveCollectionLineAggregator() - 类 的构造器org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
 
reducer(PartitionReducer) - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
refCursorPosition(int) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The parameter position of the REF CURSOR.
ReferenceJobFactory - org.springframework.batch.core.configuration.support中的类
A JobFactory that just keeps a reference to a Job.
ReferenceJobFactory(Job) - 类 的构造器org.springframework.batch.core.configuration.support.ReferenceJobFactory
 
ReflectionUtils - org.springframework.batch.support中的类
Provides reflection based utilities for Spring Batch that are not available via Spring Core
REG_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
RegexLineTokenizer - org.springframework.batch.item.file.transform中的类
Line-tokenizer using a regular expression to filter out data (by using matching and non-matching groups).
RegexLineTokenizer() - 类 的构造器org.springframework.batch.item.file.transform.RegexLineTokenizer
 
register(E) - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Register a context with the current thread - always put a matching SynchronizationManagerSupport.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(E, BatchPropertyContext) - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Register a context with the current thread - always put a matching SynchronizationManagerSupport.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(String, Collection<Step>) - 接口 中的方法org.springframework.batch.core.configuration.StepRegistry
Registers all the step of the given job.
register(String, Collection<Step>) - 类 中的方法org.springframework.batch.core.configuration.support.MapStepRegistry
 
register(RetryProcessListener) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryProcessListener
Register an additional RetryProcessListener.
register(RetryReadListener) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryReadListener
Register an additional RetryReadListener.
register(RetryWriteListener) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryWriteListener
Register an additional RetryWriteListener.
register(ChunkListener) - 类 中的方法org.springframework.batch.core.listener.CompositeChunkListener
Register additional listener.
register(JobFactory) - 接口 中的方法org.springframework.batch.core.configuration.JobRegistry
Registers a Job at runtime.
register(JobFactory) - 类 中的方法org.springframework.batch.core.configuration.support.MapJobRegistry
 
register(ItemProcessListener<? super T, ? super S>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemProcessListener
Register additional listener.
register(ItemReadListener<? super T>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemReadListener
Register additional listener.
register(ItemWriteListener<? super S>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemWriteListener
Register additional listener.
register(JobExecution) - 类 中的静态方法org.springframework.batch.core.scope.context.JobSynchronizationManager
Register a context with the current thread - always put a matching JobSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(JobExecutionListener) - 类 中的方法org.springframework.batch.core.listener.CompositeJobExecutionListener
Register additional listener.
register(SkipListener<? super T, ? super S>) - 类 中的方法org.springframework.batch.core.listener.CompositeSkipListener
Register additional listener.
register(StepExecution) - 类 中的静态方法org.springframework.batch.core.scope.context.StepSynchronizationManager
Register a context with the current thread - always put a matching StepSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(StepExecutionListener) - 类 中的方法org.springframework.batch.core.listener.CompositeStepExecutionListener
Register additional listener.
register(StepExecution, BatchPropertyContext) - 类 中的静态方法org.springframework.batch.core.scope.context.StepSynchronizationManager
Register a context with the current thread - always put a matching StepSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(StepListener) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
Register the listener for callbacks on the appropriate interfaces implemented.
register(ItemStream) - 类 中的方法org.springframework.batch.item.support.CompositeItemStream
Register a ItemStream as one of the interesting providers under the provided key.
register(RepeatContext) - 类 中的静态方法org.springframework.batch.repeat.support.RepeatSynchronizationManager
Method for registering a context - should only be used by RepeatOperations implementations to ensure that RepeatSynchronizationManager.getContext() always returns the correct value.
register(RepeatListener) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
Register additional listener.
registerAsStreamsAndListeners(ItemReader<? extends I>, ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
registerChunkListener(ChunkListener) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Register a chunk listener for callbacks at the appropriate stages in a step execution.
registerCustomEditors(PropertyEditorRegistry) - 类 中的方法org.springframework.batch.support.DefaultPropertyEditorRegistrar
Register the custom editors with the given registry.
registerDestructionCallback(String, Runnable) - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Allow clients to register callbacks for clean up on close.
registerDestructionCallback(String, Runnable) - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Allow clients to register callbacks for clean up on close.
registerDestructionCallback(String, Runnable) - 类 中的方法org.springframework.batch.core.scope.JobScope
 
registerDestructionCallback(String, Runnable) - 类 中的方法org.springframework.batch.core.scope.StepScope
 
registerDestructionCallback(String, Runnable) - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
registerDestructionCallback(String, Runnable) - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Register a callback to be executed on close, associated with the attribute having the given name.
REGISTERED_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
registerItemListeners(SimpleStepBuilder<I, O>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
registerItemStream(ItemStream) - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
registerJobExecutionListener(JobExecutionListener) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Register a single listener for the JobExecutionListener callbacks.
registerListener(StepListener) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
Register a listener for callbacks at the appropriate stages in a process.
registerListener(RepeatListener) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Register an additional listener.
registerListener(RetryListener) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
registerStepExecutionListener(StepExecutionListener) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Register a step listener for callbacks at the appropriate stages in a step execution.
registerStepListenerAsChunkListener() - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
registerStepListenerAsItemListener() - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
 
registerStepListenerAsSkipListener() - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
registerStream(ItemStream) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Register a single ItemStream for callbacks to the stream interface.
release() - 类 中的静态方法org.springframework.batch.core.scope.context.JobSynchronizationManager
A convenient "deep" close operation.
release() - 类 中的静态方法org.springframework.batch.core.scope.context.StepSynchronizationManager
A convenient "deep" close operation.
release() - 类 中的方法org.springframework.batch.core.scope.context.SynchronizationManagerSupport
A convenient "deep" close operation.
reload(ApplicationContextFactory) - 类 中的方法org.springframework.batch.core.configuration.support.DefaultJobLoader
 
reload(ApplicationContextFactory) - 接口 中的方法org.springframework.batch.core.configuration.support.JobLoader
Load an application context and register all the jobs, having first unregistered them if already registered.
RemoteChunkHandlerFactoryBean<T> - org.springframework.batch.integration.chunk中的类
Convenient factory bean for a chunk handler that also converts an existing chunk-oriented step into a remote chunk master.
RemoteChunkHandlerFactoryBean() - 类 的构造器org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
 
remoteChunkingJob() - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
RemoteChunkingMasterParser - org.springframework.batch.integration.config.xml中的类
Parser for the remote-chunking-master namespace element.
RemoteChunkingMasterParser() - 类 的构造器org.springframework.batch.integration.config.xml.RemoteChunkingMasterParser
 
RemoteChunkingMasterStepBuilder<I,​O> - org.springframework.batch.integration.chunk中的类
Builder for a master step in a remote chunking setup.
RemoteChunkingMasterStepBuilder(String) - 类 的构造器org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
remoteChunkingMasterStepBuilderFactory() - 类 中的方法org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemoteChunkingMasterStepBuilderFactory - org.springframework.batch.integration.chunk中的类
Convenient factory for a RemoteChunkingMasterStepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
RemoteChunkingMasterStepBuilderFactory(JobRepository, PlatformTransactionManager) - 类 的构造器org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilderFactory
RemoteChunkingSlaveParser - org.springframework.batch.integration.config.xml中的类
Parser for the remote-chunking-slave namespace element.
RemoteChunkingSlaveParser() - 类 的构造器org.springframework.batch.integration.config.xml.RemoteChunkingSlaveParser
 
remoteChunkingWorkerBuilder() - 类 中的方法org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemoteChunkingWorkerBuilder<I,​O> - org.springframework.batch.integration.chunk中的类
Builder for a worker in a remote chunking setup.
RemoteChunkingWorkerBuilder() - 类 的构造器org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
 
remotePartitioningJob() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
remotePartitioningJob() - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.MasterConfiguration
 
RemotePartitioningMasterStepBuilder - org.springframework.batch.integration.partition中的类
Builder for a master step in a remote partitioning setup.
RemotePartitioningMasterStepBuilder(String) - 类 的构造器org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
remotePartitioningMasterStepBuilderFactory() - 类 中的方法org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningMasterStepBuilderFactory - org.springframework.batch.integration.partition中的类
Convenient factory for a RemotePartitioningMasterStepBuilder which sets the JobRepository, JobExplorer, BeanFactory and PlatformTransactionManager automatically.
RemotePartitioningMasterStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - 类 的构造器org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
RemotePartitioningWorkerStepBuilder - org.springframework.batch.integration.partition中的类
Builder for a worker step in a remote partitioning setup.
RemotePartitioningWorkerStepBuilder(String) - 类 的构造器org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Initialize a step builder for a step with the given name.
remotePartitioningWorkerStepBuilderFactory() - 类 中的方法org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningWorkerStepBuilderFactory - org.springframework.batch.integration.partition中的类
Convenient factory for a RemotePartitioningWorkerStepBuilder which sets the JobRepository, JobExplorer, BeanFactory and PlatformTransactionManager automatically.
RemotePartitioningWorkerStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - 类 的构造器org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
RemoteStepExecutionAggregator - org.springframework.batch.core.partition.support中的类
Convenience class for aggregating a set of StepExecution instances when the input comes from remote steps, so the data need to be refreshed from the repository.
RemoteStepExecutionAggregator() - 类 的构造器org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Create a new instance (useful for configuration purposes).
RemoteStepExecutionAggregator(JobExplorer) - 类 的构造器org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Create a new instance with a job explorer that can be used to refresh the data when aggregating.
remove() - 类 中的方法org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
remove() - 类 中的方法org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove(String) - 类 中的方法org.springframework.batch.core.scope.JobScope
 
remove(String) - 类 中的方法org.springframework.batch.core.scope.StepScope
 
remove(String) - 类 中的方法org.springframework.batch.item.ExecutionContext
Removes the mapping for a key from this context if it is present.
remove(Throwable) - 类 中的方法org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
removeAttribute(String) - 类 中的方法org.springframework.batch.core.scope.context.JobContext
Override base class behaviour to ensure destruction callbacks are unregistered as well as the default behaviour.
removeAttribute(String) - 类 中的方法org.springframework.batch.core.scope.context.StepContext
Override base class behaviour to ensure destruction callbacks are unregistered as well as the default behaviour.
removeAttribute(String) - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
removeJobExecutions() - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
Remove all the JobExecution instances, and all associated JobInstance and StepExecution instances from the standard RDBMS locations used by Spring Batch.
removeJobExecutions(Collection<JobExecution>) - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
Remove the JobExecution instances, and all associated JobInstance and StepExecution instances from the standard RDBMS locations used by Spring Batch.
RepeatCallback - org.springframework.batch.repeat中的接口
Callback interface for batch operations.
RepeatContext - org.springframework.batch.repeat中的接口
Base interface for context which controls the state and completion / termination of a batch step.
RepeatContextCounter - org.springframework.batch.repeat.context中的类
Helper class for policies that need to count the number of occurrences of some event (e.g. an exception type in the context) in the scope of a batch.
RepeatContextCounter(RepeatContext, String) - 类 的构造器org.springframework.batch.repeat.context.RepeatContextCounter
Convenience constructor with useParent=false.
RepeatContextCounter(RepeatContext, String, boolean) - 类 的构造器org.springframework.batch.repeat.context.RepeatContextCounter
Construct a new RepeatContextCounter.
RepeatContextSupport - org.springframework.batch.repeat.context中的类
 
RepeatContextSupport(RepeatContext) - 类 的构造器org.springframework.batch.repeat.context.RepeatContextSupport
Constructor for RepeatContextSupport.
RepeatException - org.springframework.batch.repeat中的异常错误
 
RepeatException(String) - 异常错误 的构造器org.springframework.batch.repeat.RepeatException
 
RepeatException(String, Throwable) - 异常错误 的构造器org.springframework.batch.repeat.RepeatException
 
RepeatInternalState - org.springframework.batch.repeat.support中的接口
Internal interface for extensions of RepeatTemplate.
RepeatInternalStateSupport - org.springframework.batch.repeat.support中的类
 
RepeatInternalStateSupport() - 类 的构造器org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
RepeatListener - org.springframework.batch.repeat中的接口
Interface for listeners to the batch process.
RepeatListenerSupport - org.springframework.batch.repeat.listener中的类
Empty method implementation of RepeatListener.
RepeatListenerSupport() - 类 的构造器org.springframework.batch.repeat.listener.RepeatListenerSupport
 
RepeatOperations - org.springframework.batch.repeat中的接口
The main interface providing access to batch operations.
RepeatOperationsInterceptor - org.springframework.batch.repeat.interceptor中的类
A MethodInterceptor that can be used to automatically repeat calls to a method on a service.
RepeatOperationsInterceptor() - 类 的构造器org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
 
RepeatStatus - org.springframework.batch.repeat中的枚举
 
RepeatSynchronizationManager - org.springframework.batch.repeat.support中的类
Global variable support for repeat clients.
RepeatTemplate - org.springframework.batch.repeat.support中的类
Simple implementation and base class for batch templates implementing RepeatOperations.
RepeatTemplate() - 类 的构造器org.springframework.batch.repeat.support.RepeatTemplate
 
replaceExitCode(String) - 类 中的方法org.springframework.batch.core.ExitStatus
Add an exit code to an existing ExitStatus.
replies() - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
replies() - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
replies() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
replies() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
repository(JobRepository) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
Sets the job repository for the job.
repository(JobRepository) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
repository(JobRepository) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
repository(JobRepository) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
repository(JobRepository) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
repository(RepositoryItemReaderBuilder.RepositoryMethodReference) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Specifies a repository and the type-safe method to call for the reader.
repository(RepositoryItemWriterBuilder.RepositoryMethodReference) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
Specifies a repository and the type-safe method to call for the writer.
repository(CrudRepository<T, ?>) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
Set the CrudRepository implementation for persistence
repository(PagingAndSortingRepository<?, ?>) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
The PagingAndSortingRepository implementation used to read input from.
RepositoryItemReader<T> - org.springframework.batch.item.data中的类
A ItemReader that reads records utilizing a PagingAndSortingRepository.
RepositoryItemReader() - 类 的构造器org.springframework.batch.item.data.RepositoryItemReader
 
RepositoryItemReaderBuilder<T> - org.springframework.batch.item.data.builder中的类
A builder implementation for the RepositoryItemReader.
RepositoryItemReaderBuilder() - 类 的构造器org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
 
RepositoryItemReaderBuilder.RepositoryMethodReference<T> - org.springframework.batch.item.data.builder中的类
Establishes a proxy that will capture a the Repository and the associated methodName that will be used by the reader.
RepositoryItemWriter<T> - org.springframework.batch.item.data中的类
A ItemReader wrapper for a CrudRepository from Spring Data.
RepositoryItemWriter() - 类 的构造器org.springframework.batch.item.data.RepositoryItemWriter
 
RepositoryItemWriterBuilder<T> - org.springframework.batch.item.data.builder中的类
A builder implementation for the RepositoryItemWriter.
RepositoryItemWriterBuilder() - 类 的构造器org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
 
RepositoryItemWriterBuilder.RepositoryMethodReference<T> - org.springframework.batch.item.data.builder中的类
Establishes a proxy that will capture a the Repository and the associated methodName that will be used by the writer.
RepositoryMethodReference(CrudRepository<?, ?>) - 类 的构造器org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder.RepositoryMethodReference
 
RepositoryMethodReference(PagingAndSortingRepository<?, ?>) - 类 的构造器org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder.RepositoryMethodReference
 
requests() - 类 中的方法org.springframework.batch.sample.remotechunking.MasterConfiguration
 
requests() - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
requests() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.MasterConfiguration
 
requests() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
requests() - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.MasterConfiguration
 
requests() - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.WorkerConfiguration
 
requiresTransactionManager() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
reset() - 类 中的方法org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
reset() - 接口 中的方法org.springframework.batch.item.xml.stax.FragmentEventReader
Reset the state of the fragment reader - make it forget it assumptions about current position of cursor (e.g. in case of rollback of the wrapped reader).
resetCounter() - 类 中的方法org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
resetOffset() - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
resolveContextualObject(String) - 类 中的方法org.springframework.batch.core.scope.JobScope
This will be used to resolve expressions in job-scoped beans.
resolveContextualObject(String) - 类 中的方法org.springframework.batch.core.scope.StepScope
This will be used to resolve expressions in step-scoped beans.
resolveId(Element, AbstractBeanDefinition, ParserContext) - 类 中的方法org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
resolveValue(Object) - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport.Scopifier
 
resource(Resource) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The Resource to be used as input.
resource(Resource) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
The Resource to be used as output.
resource(Resource) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Prototype for output resources.
resource(Resource) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
The Resource to be used as output.
resource(Resource) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
The Resource to be used as input.
resource(Resource) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Establishes the resource that will be used as the input for the LdifReader.
resource(Resource) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Establishes the resource that will be used as the input for the MappingLdifReader.
resource(Resource) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
The Resource to be used as input.
resource(Resource) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The Resource to be used as output.
ResourceAware - org.springframework.batch.item中的接口
Marker interface indicating that an item should have the Spring Resource in which it was read from, set on it.
ResourceAwareItemReaderItemStream<T> - org.springframework.batch.item.file中的接口
Interface for ItemReaders that implement ItemStream and read input from Resource.
ResourceAwareItemWriterItemStream<T> - org.springframework.batch.item.file中的接口
Interface for ItemWriters that implement ItemStream and write output to Resource.
ResourcelessTransactionManager - org.springframework.batch.support.transaction中的类
 
ResourcelessTransactionManager() - 类 的构造器org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
resources(Resource[]) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
The array of resources that the MultiResourceItemReader will use to retrieve items.
ResourcesItemReader - org.springframework.batch.item.file中的类
ItemReader which produces Resource instances from an array.
ResourcesItemReader() - 类 的构造器org.springframework.batch.item.file.ResourcesItemReader
 
resourceSuffixCreator(ResourceSuffixCreator) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Allows customization of the suffix of the created resources based on the index.
ResourceSuffixCreator - org.springframework.batch.item.file中的接口
Strategy interface for translating resource index into unique filename suffix.
restart(long) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Restart a failed or stopped JobExecution.
restart(long) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
restart(long, Properties) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
Creates a child ApplicationContext for the job being requested based upon the /META-INF/batch.xml (if exists) and the /META-INF/batch-jobs/<jobName>.xml configuration and restart the job.
RESTART_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
restartJob(long, Properties, long) - 类 中的静态方法org.springframework.batch.test.JsrTestUtils
Restarts a job and waits for it's status to be any of BatchStatus.STOPPED, BatchStatus.COMPLETED, or BatchStatus.FAILED.
restoreFrom(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
ResultHolderResultQueue - org.springframework.batch.repeat.support中的类
An implementation of the ResultQueue that throttles the number of expected results, limiting it to a maximum at any given time.
ResultHolderResultQueue(int) - 类 的构造器org.springframework.batch.repeat.support.ResultHolderResultQueue
 
results - 类 中的变量org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
results - 类 中的变量org.springframework.batch.item.database.AbstractPagingItemReader
 
resume(String, FlowExecutor) - 接口 中的方法org.springframework.batch.core.job.flow.Flow
 
resume(String, FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
RETHROW - org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Key for Classifier signalling that the throwable should be rethrown.
RethrowOnThresholdExceptionHandler - org.springframework.batch.repeat.exception中的类
Implementation of ExceptionHandler that rethrows when exceptions of a given type reach a threshold.
RethrowOnThresholdExceptionHandler() - 类 的构造器org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Set up the exception handler.
retry(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly ask for an exception (and subclasses) to be retried.
retry(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
RETRY_PROCESS - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
RETRY_READ - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
RETRY_WRITE - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
retryContextCache(RetryContextCache) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry context cache.
retryContextCache(RetryContextCache) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
retryLimit(int) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
The maximum number of times to try a failed item.
retryLimit(int) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
RetryListener - org.springframework.batch.core.jsr中的接口
Interface used internally by RetryListener adapters to provide consistent naming.
retryPolicy(RetryPolicy) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry policy instead of using the FaultTolerantStepBuilder.retryLimit(int) and retryable exceptions provided elsewhere.
retryPolicy(RetryPolicy) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
RetryProcessListenerAdapter - org.springframework.batch.core.jsr中的类
Wrapper class to adapt a RetryProcessListener to a RetryListener.
RetryProcessListenerAdapter(RetryProcessListener) - 类 的构造器org.springframework.batch.core.jsr.RetryProcessListenerAdapter
 
RetryReadListenerAdapter - org.springframework.batch.core.jsr中的类
Wrapper class to adapt a RetryReadListener to a RetryListener.
RetryReadListenerAdapter(RetryReadListener) - 类 的构造器org.springframework.batch.core.jsr.RetryReadListenerAdapter
 
retrySample() - 类 中的方法org.springframework.batch.sample.config.RetrySampleConfiguration
 
RetrySampleConfiguration - org.springframework.batch.sample.config中的类
 
RetrySampleConfiguration() - 类 的构造器org.springframework.batch.sample.config.RetrySampleConfiguration
 
RetrySampleItemWriter<T> - org.springframework.batch.sample.support中的类
Simulates temporary output trouble - requires to retry 3 times to pass successfully.
RetrySampleItemWriter() - 类 的构造器org.springframework.batch.sample.support.RetrySampleItemWriter
 
RetryWriteListenerAdapter - org.springframework.batch.core.jsr中的类
Wrapper class to adapt a RetryWriteListener to a RetryListener.
RetryWriteListenerAdapter(RetryWriteListener) - 类 的构造器org.springframework.batch.core.jsr.RetryWriteListenerAdapter
 
returnStatement(String) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The return statement of the cypher query.
RIGHT - org.springframework.batch.item.file.transform.Alignment
 
ROLLBACK_EXCEPTION_KEY - 接口 中的静态变量org.springframework.batch.core.ChunkListener
 
rootElementAttributes(Map<String, String>) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
A Map of attributes to be included in the document's root element.
rootTagName(String) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The name of the root tag for the output document.
rowMapper(RowMapper<T>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The RowMapper used to map the results of the cursor to each item.
rowMapper(RowMapper<T>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The RowMapper used to map the query results to objects.
rowMapper(RowMapper<T>) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The RowMapper used to map the results of the cursor to each item.
rs - 类 中的变量org.springframework.batch.item.database.AbstractCursorItemReader
 
run(Job, JobParameters) - 接口 中的方法org.springframework.batch.core.launch.JobLauncher
Start a job execution for the given Job and JobParameters .
run(Job, JobParameters) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobLauncher
Run the provided job with the given JobParameters.
RunIdIncrementer - org.springframework.batch.core.launch.support中的类
 
RunIdIncrementer() - 类 的构造器org.springframework.batch.core.launch.support.RunIdIncrementer
 
runJob(String, Properties, long) - 类 中的静态方法org.springframework.batch.test.JsrTestUtils
Executes a job and waits for it's status to be any of BatchStatus.STOPPED, BatchStatus.COMPLETED, or BatchStatus.FAILED.
RuntimeExceptionTranslator - org.springframework.batch.core.launch.support中的类
 
RuntimeExceptionTranslator() - 类 的构造器org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 

S

saveExecutionContext(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given jobExecution, persistent entry for the context should not exist yet.
saveExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContext(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given stepExecution, persistent entry for the context should not exist yet.
saveExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with each stepExecution in a given collection, persistent entry for the context should not exist yet.
saveExecutionContexts(Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveJobExecution(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
SQL implementation using Sequences via the Spring incrementer abstraction.
saveJobExecution(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
Save a new JobExecution.
saveJobExecution(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
savePlayer(Player) - 接口 中的方法org.springframework.batch.core.test.football.PlayerDao
 
savePlayer(Player) - 类 中的方法org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
savePlayer(Player) - 接口 中的方法org.springframework.batch.sample.domain.football.PlayerDao
 
saveState(boolean) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Indicates if the state of the writer should be saved in the ExecutionContext.
saveStepExecution(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Save a StepExecution.
saveStepExecution(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecution(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given StepExecution.
saveStepExecutions(Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Batch insert StepExecutions
saveStepExecutions(Collection<StepExecution>) - 类 中的方法org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecutions(Collection<StepExecution>) - 接口 中的方法org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given collection of StepExecution as a batch.
SCHEDULE_DATE_KEY - 类 中的静态变量org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
ScheduledJobParametersFactory - org.springframework.batch.core.launch.support中的类
 
ScheduledJobParametersFactory() - 类 的构造器org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
Scopifier(BeanDefinitionRegistry, String, boolean, boolean) - 类 的构造器org.springframework.batch.core.scope.BatchScopeSupport.Scopifier
 
ScriptItemProcessor<I,​O> - org.springframework.batch.item.support中的类
ItemProcessor implementation that passes the current item to process to the provided script.
ScriptItemProcessor() - 类 的构造器org.springframework.batch.item.support.ScriptItemProcessor
 
ScriptItemProcessorBuilder<I,​O> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified ScriptItemProcessor.
ScriptItemProcessorBuilder() - 类 的构造器org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
 
scriptResource(Resource) - 类 中的方法org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Sets the Resource location of the script to use.
scriptSource(String) - 类 中的方法org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Sets the provided String as the script source code to use.
selectClause(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL SELECT clause for a db specific PagingQueryProvider.
selectImports(AnnotationMetadata) - 类 中的方法org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
send(SimpleMailMessage) - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
send(SimpleMailMessage...) - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
serialize(Map<String, Object>, OutputStream) - 类 中的方法org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
Serializes an execution context to the provided OutputStream.
serialize(Map<String, Object>, OutputStream) - 类 中的方法org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
serialize(Map<String, Object>, OutputStream) - 类 中的方法org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
Serializes the passed execution context to the supplied OutputStream.
sessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The Hibernate SessionFactory to execute the query against.
sessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
The Hibernate SessionFactory to obtain a session from.
sessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The Hibernate SessionFactory to execute the query against.
sessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Establish the session factory for the reader.
sessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
Establish the session factory that will be used to create Session instances for interacting with Neo4j.
setAddress(String) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setAddress(Address) - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
setAddressee(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
setAddressMapper(FieldSetMapper<Address>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setAddrLine1(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
setAddrLine2(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
setAdviceChain(Advice[]) - 类 中的方法org.springframework.batch.container.jms.BatchMessageListenerContainer
Public setter for the Advice.
setAge(int) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setAge(int) - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
setAggregators(Map<String, LineAggregator<Object>>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
Set aggregators for all types of lines in the output file
setAllowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
setAllowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setAllowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Flag to indicate that the partition target step is allowed to start if an execution is complete.
setAllowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Public setter for flag that determines whether the step should start again if it is already complete.
setAllowStartIfComplete(boolean) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
setAllowStartIfComplete(Boolean) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setAncestorsCompleteOnly() - 类 中的静态方法org.springframework.batch.repeat.support.RepeatSynchronizationManager
Set current session and all ancestors (via parent) to complete
setAppendAllowed(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setAppendAllowed(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that the target file should be appended if it already exists.
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The enclosing application context, which can be used to check if events come from the expected source.
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
An application context that can be used as a parent context for all the factories.
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
setApplicationContext(ApplicationContext) - 类 中的方法org.springframework.batch.test.AbstractJobTests
已过时。
setApplicationContextFactories(ApplicationContextFactory[]) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
setApplicationEventPublisher(ApplicationEventPublisher) - 类 中的方法org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
setArguments(Object[]) - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setArguments(List<?>) - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
Arguments to be passed to the data providing method.
setArtifactProperties(Map<String, Properties>) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds non-step artifact properties to the context.
setAssertUpdates(boolean) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the flag that determines whether an assertion is made that all items cause at least one row to be updated.
setAsText(String) - 类 中的方法org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
setAsText(String) - 类 中的方法org.springframework.batch.support.IntArrayPropertyEditor
 
setAttempts(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setAttempts(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setAttempts(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setAttempts(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setAttribute(String, Object) - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
setAttributeIfAbsent(String, Object) - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
Additional support for atomic put if absent.
setAutoProxy(boolean) - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
Flag to indicate that bean definitions need not be auto proxied.
setAutoStartup(boolean) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
setBackOffPolicy(BackOffPolicy) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
A backoff policy to be applied to retry process.
setBackOffPolicy(BackOffPolicy) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the BackOffPolicy.
setBackOffPolicy(BackOffPolicy) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrBatchletStepBuilder
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
setBatchPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
setBeanFactory(BeanFactory) - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
setBeanFactory(BeanFactory) - 类 中的方法org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
setBeanFactory(BeanFactory) - 类 中的方法org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
setBeanFactory(BeanFactory) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
 
setBeanFactory(BeanFactory) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
 
setBeanFactory(BeanFactory) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Determines which bean factory post processors (like property placeholders) should be copied from the parent context.
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Determines which bean factory post processors (like property placeholders) should be copied from the parent context.
setBeanName(String) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Set the bean name property, which will become the name of the Step when it is created.
setBeanName(String) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Set the name property if it is not already set.
setBeanName(String) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Set the name property if it is not already set.
setBeanName(String) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Set the bean name property, which will become the name of the Step when it is created.
setBeanPostProcessorExcludeClasses(Class<?>[]) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Determines by exclusion which bean post processors should be copied from the parent context.
setBeanPostProcessorExcludeClasses(Class<?>[]) - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Determines by exclusion which bean post processors should be copied from the parent context.
setBegin(String) - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the begin value.
setBilling(BillingInfo) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setBillingAddress(Address) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setBillingMapper(FieldSetMapper<BillingInfo>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setBirthYear(int) - 类 中的方法org.springframework.batch.core.test.football.Player
 
setBirthYear(int) - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
setBufferedReaderFactory(BufferedReaderFactory) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Factory for the BufferedReader that will be used to extract lines from the file.
setBuffering(boolean) - 类 中的方法org.springframework.batch.core.step.item.ChunkOrientedTasklet
Flag to indicate that items should be buffered once read.
setBuffering(boolean) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A flag to indicate that items have been buffered and therefore will always come back as a chunk after a rollback.
setBusinessCustomer(boolean) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setBusy(boolean) - 类 中的方法org.springframework.batch.core.step.item.Chunk
Register an interest in the chunk to prevent it from being cleaned up before the flag is reset to false.
setCacheCapacity(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the capacity of the cache in the retry policy.
setCacheCapacity(int) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the capacity of the cache in the retry policy.
setCallable(Callable<RepeatStatus>) - 类 中的方法org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Public setter for the Callable.
setChannel(MessageChannel) - 类 中的方法org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Optional MessageChannel for injecting the message received from the source (defaults to the channel intercepted in MessageSourcePollerInterceptor.preReceive(MessageChannel)).
setChildren(List<Child>) - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
setChunk(SimpleStepBuilder<I, O>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setChunk(SimpleStepBuilder<I, O>) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setChunkCompletionPolicy(CompletionPolicy) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the CompletionPolicy applying to the chunk level.
setChunkCompletionPolicy(CompletionPolicy) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the CompletionPolicy applying to the chunk level.
setChunkListeners(ChunkListener[]) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the objects as listeners.
setChunkMonitor(ChunkMonitor) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
setChunkMonitor(ChunkMonitor) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setChunkOperations(RepeatOperations) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the chunkOperations.
setChunkProcessor(ChunkProcessor<S>) - 类 中的方法org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
Public setter for the ChunkProcessor.
setChunkSize(int) - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
setChunkSize(int) - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
setChunkWriter(ItemWriter<T>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The item writer to be injected into the step.
setCity(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
setClassifier(Classifier<? super I, ItemProcessor<?, ? extends O>>) - 类 中的方法org.springframework.batch.item.support.ClassifierCompositeItemProcessor
Establishes the classifier that will determine which ItemProcessor to use.
setClassifier(Classifier<T, ItemWriter<? super T>>) - 类 中的方法org.springframework.batch.item.support.ClassifierCompositeItemWriter
 
setClearSession(boolean) - 类 中的方法org.springframework.batch.item.database.HibernateItemWriter
Flag to indicate that the session should be cleared and flushed at the end of the write (default true).
setClobType(int) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setClobTypeToUse(int) - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setCollection(String) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
 
setCollection(String) - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
Set the name of the Mongo collection to be written to.
setColumn(String) - 类 中的方法org.springframework.batch.sample.common.ColumnRangePartitioner
The name of the column to partition.
setColumns(Range...) - 类 中的方法org.springframework.batch.item.file.transform.FixedLengthTokenizer
Set the column ranges.
setCommand(String) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setComments(String[]) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Setter for comment prefixes.
setCommitCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the current number of commits for this execution
setCommitInterval(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Set the commit interval.
setCommitInterval(int) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Set the commit interval.
setCompanyName(String) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setComparator(Comparator<Resource>) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
 
setComplete() - 类 中的方法org.springframework.batch.core.scope.context.ChunkContext
Setter for the flag to signal complete processing of a chunk.
setCompleteOnly() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
setCompleteOnly() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete normally, independent of the current CompletionPolicy.
setCompleteOnly() - 类 中的静态方法org.springframework.batch.repeat.support.RepeatSynchronizationManager
Convenience method to set the current repeat operation to complete if it exists.
setCompletes(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setCompletes(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setCompletes(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setCompletes(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setCompletionPolicy(CompletionPolicy) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Setter for policy to decide when the batch is complete.
setConnectionAutoCommit(boolean) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Set whether "autoCommit" should be overridden for the connection used by the cursor.
setContinuation(String) - 类 中的方法org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the continuation.
setConversionService(ConversionService) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the 'conversionService' property.
setCopyConfiguration(boolean) - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the parent context.
setCopyConfiguration(boolean) - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the parent context.
setCountry(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
setCreateTime(Date) - 类 中的方法org.springframework.batch.core.JobExecution
 
setCredit(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
setCreditFilter(double) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
setCurrentItemCount(int) - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The index of the item to start reading from.
setCustomEditors(Map<? extends Object, ? extends PropertyEditor>) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Specify the custom editors to register.
setCustomEditors(Map<? extends Object, ? extends PropertyEditor>) - 类 中的方法org.springframework.batch.support.DefaultPropertyEditorRegistrar
Specify the custom editors to register.
setCustomer(String) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
setCustomer(Customer) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setCustomer(Customer) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
setCustomerCreditDao(CustomerCreditDao) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
Public setter for the CustomerCreditDao.
setCustomerDao(CustomerDao) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
setCustomerDao(CustomerDao) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
setCustomerMapper(FieldSetMapper<Customer>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setCustomerTokenizer(LineTokenizer) - 类 中的方法org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
Set the LineTokenizer that will be used to tokenize any lines that begin with A, U, or D, and are thus a customer operation.
setDao(CustomerCreditDao) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
setDao(CustomerCreditDao) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
setDao(CustomerDebitDao) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
setDao(TradeDao) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
setDatabaseType(String) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the database type.
setDatabaseType(String) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
Sets the dataSource.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
DataSource pointing to the job repository
setDataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Public setter for the data source for injection purposes.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Setter for the DataSource that is to be wrapped.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the data source for injection purposes.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.common.ColumnRangePartitioner
The data source for connecting to the database.
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.common.StagingItemListener
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.common.StagingItemProcessor
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.common.StagingItemReader
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.test.DataSourceInitializer
 
setDataSource(DataSource) - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
 
setDate(Date) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
setDateFormat(DateFormat) - 类 中的方法org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for injecting a date format.
setDateFormat(DateFormat) - 类 中的方法org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Public setter for injecting a date format.
setDateFormat(DateFormat) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
The DateFormat to use for parsing numbers.
setDateFormat(DateFormat) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The DateFormat to use for parsing numbers.
setDebit(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
setDebutYear(int) - 类 中的方法org.springframework.batch.core.test.football.Player
 
setDebutYear(int) - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
setDecider(Decider) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
setDefaultValue(String) - 类 中的方法org.springframework.batch.support.SystemPropertyInitializer
Mandatory property specifying the default value of the System property.
setDelegate(Object) - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setDelegate(StepExecutionAggregator) - 类 中的方法org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setDelegate(Step) - 类 中的方法org.springframework.batch.integration.step.DelegateStep
 
setDelegate(FieldSetMapper<T>) - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the delegate.
setDelegate(ResourceAwareItemReaderItemStream<? extends T>) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
 
setDelegate(ResourceAwareItemWriterItemStream<? super T>) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
Delegate used for actual writing of the output.
setDelegate(LineAggregator<T>) - 类 中的方法org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
Public setter for the LineAggregator to use on single items, that are not Strings.
setDelegate(ItemProcessor<I, O>) - 类 中的方法org.springframework.batch.integration.async.AsyncItemProcessor
The ItemProcessor to use to delegate processing to in a background thread.
setDelegate(ItemReader<T>) - 类 中的方法org.springframework.batch.item.support.SingleItemPeekableItemReader
The item reader to use as a delegate.
setDelegate(ItemReader<T>) - 类 中的方法org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
setDelegate(ItemStreamReader<T>) - 类 中的方法org.springframework.batch.item.support.SynchronizedItemStreamReader
 
setDelegate(ItemWriter<T>) - 类 中的方法org.springframework.batch.integration.async.AsyncItemWriter
 
setDelegates(List<? extends ItemProcessor<?, ?>>) - 类 中的方法org.springframework.batch.item.support.CompositeItemProcessor
Establishes the ItemProcessor delegates that will work on the item to be processed.
setDelegates(List<ItemWriter<? super T>>) - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
The list of item writers to use as delegates.
setDelete(boolean) - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
Indicates if the items being passed to the writer are to be saved or removed from the data store.
setDelete(boolean) - 类 中的方法org.springframework.batch.item.data.Neo4jItemWriter
Boolean flag indicating whether the writer should save or delete the item at write time.
setDelete(boolean) - 类 中的方法org.springframework.batch.item.KeyValueItemWriter
Sets the delete flag to have the item writer perform deletes
setDeleteIfExists(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setDelimiter(String) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineAggregator
Public setter for the delimiter.
setDelimiter(String) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Setter for the delimiter character.
setDescription(String) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setDestroyScripts(Resource[]) - 类 中的方法org.springframework.batch.test.DataSourceInitializer
 
setDiscountAmount(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setDiscountPerc(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setDistanceLimit(int) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
The maximum difference that can be tolerated in spelling between input key names and bean property names.
setDriverSupportsAbsolute(boolean) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Indicate whether the JDBC driver supports setting the absolute row on a ResultSet.
setEmail(String) - 类 中的方法org.springframework.batch.sample.domain.mail.User
 
setEncoding(String) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Setter for the encoding for this input source.
setEncoding(String) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setEncoding(String) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Sets encoding for output template.
setEncoding(String) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set encoding to be used for output file.
setEncoding(String) - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
setEnd() - 类 中的方法org.springframework.batch.core.step.item.Chunk
Set the flag to say that this chunk represents an end of stream (there is no more data to process).
setEnd(String) - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the end field value.
setEndTime(Date) - 类 中的方法org.springframework.batch.core.JobExecution
 
setEndTime(Date) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the time that this execution ended
setEntityClass(Class<E>) - 类 中的方法org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
setEntityClass(Class<E>) - 类 中的方法org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
setEntityManager(EntityManager) - 类 中的方法org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
Public setter to override the entityManager that was created by this HibernateQueryProvider.
setEntityManager(EntityManager) - 接口 中的方法org.springframework.batch.item.database.orm.JpaQueryProvider
Provide an EntityManager for the query to be built.
setEntityManagerFactory(EntityManagerFactory) - 类 中的方法org.springframework.batch.item.database.JpaItemWriter
Set the EntityManager to be used internally.
setEntityManagerFactory(EntityManagerFactory) - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
setEnvironmentParams(String[]) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setExceptionClasses(Collection<Class<? extends Throwable>>) - 类 中的方法org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the exception classes that this handler counts.
setExceptionClassifier(Classifier<Throwable, LogOrRethrowExceptionHandler.Level>) - 类 中的方法org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Setter for the Classifier used by this handler.
setExceptionClassifier(SubclassClassifier<Throwable, SkipPolicy>) - 类 中的方法org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
The classifier that will be used to choose a delegate policy.
setExceptionHandler(ExceptionHandler) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the ExceptionHandler.
setExceptionHandler(ExceptionHandler) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Setter for exception handler strategy.
setExecutionContext(ExecutionContext) - 类 中的方法org.springframework.batch.core.job.SimpleStepHandler
A context containing values to be added to the step execution before it is handled.
setExecutionContext(ExecutionContext) - 类 中的方法org.springframework.batch.core.JobExecution
Sets the ExecutionContext for this execution
setExecutionContext(ExecutionContext) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the ExecutionContext for this execution
setExecutionContextName(String) - 类 中的方法org.springframework.batch.item.ItemStreamSupport
 
setExitCodeMapper(ExitCodeMapper) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the ExitCodeMapper.
setExitMessageLength(int) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Public setter for the exit message length in database.
setExitMessageLength(int) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Public setter for the exit message length in database.
setExitStatus(String) - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
setExitStatus(String) - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
setExitStatus(ExitStatus) - 类 中的方法org.springframework.batch.core.JobExecution
 
setExitStatus(ExitStatus) - 类 中的方法org.springframework.batch.core.StepContribution
Set the ExitStatus for this contribution.
setExitStatus(ExitStatus) - 类 中的方法org.springframework.batch.core.StepExecution
 
setExitStatus(FlowExecutor, String) - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
Performs any logic to update the exit status for the current flow.
setExitStatus(FlowExecutor, String) - 类 中的方法org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
setFailingCustomers(List<String>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
Public setter for the the customers on which failure should occur.
setFailOnFlush(int) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
Public setter for the failOnFlush property.
setFatalExceptionClasses(Collection<Class<? extends Throwable>>) - 类 中的方法org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the exception classes that shouldn't be counted, but rethrown immediately.
setFetchSize(int) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFetchSize(int) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
Fetch size used internally by Hibernate to limit amount of data fetched from database per round trip.
setFetchSize(int) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
Fetch size used internally by Hibernate to limit amount of data fetched from database per round trip.
setFetchSize(int) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFieldExtractor(FieldExtractor<T>) - 类 中的方法org.springframework.batch.item.file.transform.ExtractorLineAggregator
Public setter for the field extractor responsible for splitting an input object up into an array of objects.
setFields(String) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
JSON defining the fields to be returned from the matching documents by MongoDB.
setFieldSetFactory(FieldSetFactory) - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
Factory for FieldSet instances.
setFieldSetMapper(FieldSetMapper<T>) - 类 中的方法org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setFieldSetMappers(Map<String, FieldSetMapper<T>>) - 类 中的方法org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
setFieldSetReader(ItemReader<FieldSet>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setFieldsUsedAsTargetMethodArguments(String[]) - 类 中的方法org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
setFilter(boolean) - 类 中的方法org.springframework.batch.item.validator.ValidatingItemProcessor
Should the processor filter invalid records instead of skipping them?
setFilterCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Public setter for the number of items filtered out of this execution.
setFirstName(String) - 类 中的方法org.springframework.batch.core.test.football.Player
 
setFirstName(String) - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
setFirstName(String) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setFirstName(String) - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
setFlow(Flow) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
setFlow(Flow) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setFlow(Flow) - 类 中的方法org.springframework.batch.core.job.flow.FlowJob
Public setter for the flow.
setFlow(Flow) - 类 中的方法org.springframework.batch.core.job.flow.FlowStep
Public setter for the flow.
setFlow(Flow) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setFlowType(Class<SimpleFlow>) - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
setFooterCallback(FlatFileFooterCallback) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
footerCallback will be called after writing the last item to file, but before the file is closed.
setFooterCallback(StaxWriterCallback) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
footerCallback is called after writing all items but before closing the file.
setFooterTokenizer(LineTokenizer) - 类 中的方法org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
Set the LineTokenizer that will be used to tokenize any lines that being with F and is thus a footer record.
setForceDisjointRanges(boolean) - 类 中的方法org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
Set force disjoint ranges.
setForceSync(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that changes should be force-synced to disk on flush.
setForceSync(boolean) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Flag to indicate that changes should be force-synced to disk on flush.
setForceSync(boolean) - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Flag to indicate that changes should be force-synced to disk on flush.
setFormat(String) - 类 中的方法org.springframework.batch.item.file.transform.FormatterLineAggregator
Set the format string used to aggregate items.
setFragmentRootElementName(String) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
setFragmentRootElementNames(String[]) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
setFromClause(String) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setFromClause(String) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setFunction(boolean) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Set whether this stored procedure is a function.
setGridSize(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setGridSize(int) - 类 中的方法org.springframework.batch.core.partition.support.AbstractPartitionHandler
Passed to the StepExecutionSplitter in the AbstractPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setGridSize(int) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Passed to the StepExecutionSplitter in the MessageChannelPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setGroupClause(String) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
The setter for the group by clause
setGroupClause(String) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setGroupName(String) - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
The group name for jobs registered by this component.
setGson(Gson) - 类 中的方法org.springframework.batch.item.json.GsonJsonObjectMarshaller
Set the Gson object to use.
setHandlers(ExceptionHandler[]) - 类 中的方法org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
setHandlingPrice(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setHasChunkElement(boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setHeaderCallback(FlatFileHeaderCallback) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
headerCallback will be called before writing the first item to file.
setHeaderCallback(StaxWriterCallback) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
headerCallback is called before writing any items.
setHeaderMapper(FieldSetMapper<Order>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setHierarchicalStreamDriver(HierarchicalStreamDriver) - 类 中的方法org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
 
setHint(String) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
JSON String telling MongoDB what index to use.
setId(int) - 类 中的方法org.springframework.batch.sample.domain.mail.User
 
setId(int) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
setId(int) - 类 中的方法org.springframework.batch.sample.validation.domain.Person
 
setId(long) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
setId(Long) - 类 中的方法org.springframework.batch.core.Entity
 
setId(String) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setId(String) - 类 中的方法org.springframework.batch.core.test.football.Player
 
setId(String) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setId(String) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setId(String) - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
setId(String) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setIgnoreFailedDrop(boolean) - 类 中的方法org.springframework.batch.test.DataSourceInitializer
 
setIgnoreItemStream(boolean) - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
Establishes the policy whether to call the open, close, or update methods for the item writer delegates associated with the CompositeItemWriter.
setIgnoreWarnings(boolean) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Set whether SQLWarnings should be ignored (only logged) or exception should be thrown.
setIgnoreWhitespace(boolean) - 类 中的方法org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Flag to indicate that the decision to terminate a record should ignore whitespace at the end of the line.
setImportMetadata(AnnotationMetadata) - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
setIncludedFields(int...) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineTokenizer
The fields to include in the output by position (starting at 0).
setIncrementer(DataFieldMaxValueIncrementer) - 类 中的方法org.springframework.batch.sample.common.StagingItemWriter
Setter for the key generator for the staging table.
setIncrementer(DataFieldMaxValueIncrementer) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
setIncrementer(DataFieldMaxValueIncrementer) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
setIncrementerColumnName(String) - 类 中的方法org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
- * Public setter for the column name (defaults to "ID") in the incrementer. - * Only used by some platforms (Derby, HSQL, MySQL, SQL Server and Sybase), - * and should be fine for use with Spring Batch meta data as long as the default batch schema hasn't been changed.
setIncrementerFactory(DataFieldMaxValueIncrementerFactory) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setInitScripts(Resource[]) - 类 中的方法org.springframework.batch.test.DataSourceInitializer
 
setInputKeyName(String) - 类 中的方法org.springframework.batch.sample.common.OutputFileListener
 
setInterceptions(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setInterceptions(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setInterceptions(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setInterceptions(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setInterruptionPolicy(StepInterruptionPolicy) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Setter for the StepInterruptionPolicy.
setInterruptOnCancel(boolean) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
If true tasklet will attempt to interrupt the thread executing the system command if SystemCommandTasklet.setTimeout(long) has been exceeded or user interrupts the job.
setInvalidCustomerLogger(InvalidCustomerLogger) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
setIsin(String) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
setIsolation(Isolation) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setIsolation(Isolation) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setIsolationLevelForCreate(String) - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
public setter for the isolation level to be used for the transaction when job execution entities are initially created.
setIsReaderTransactionalQueue(boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a rollback.
setIsReaderTransactionalQueue(boolean) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a rollback.
setItemBindingVariableName(String) - 类 中的方法org.springframework.batch.item.support.ScriptItemProcessor
Provides the ability to change the key name that scripts use to obtain the current item to process if the variable represented by: ScriptItemProcessor.ITEM_BINDING_VARIABLE_NAME is not suitable ("item").
setItemCount(int) - 接口 中的方法org.springframework.batch.item.ItemCountAware
Setter for the injection of the current item count.
setItemCountLimitPerResource(int) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
After this limit is exceeded the next chunk will be written into newly created resource.
setItemId(long) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setItemKeyMapper(Converter<V, K>) - 类 中的方法org.springframework.batch.item.KeyValueItemWriter
Set the Converter to use to derive the key from the item
setItemMapper(FieldSetMapper<LineItem>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setItemPreparedStatementSetter(ItemPreparedStatementSetter<T>) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemPreparedStatementSetter.
setItemProcessor(ItemProcessor<? super I, ? extends O>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemProcessor(ItemProcessor<? super I, ? extends O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemProcessor(ItemProcessor<? super T, ? extends S>) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemReader(ItemReader<?>) - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
setItemReader(ItemReader<? extends I>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemReader(ItemReader<? extends T>) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemReader(ItemReader<AggregateItem<T>>) - 类 中的方法org.springframework.batch.sample.domain.multiline.AggregateItemReader
 
setItemSqlParameterSourceProvider(ItemSqlParameterSourceProvider<T>) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemSqlParameterSourceProvider.
setItemType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.amqp.AmqpItemReader
Establish the itemType for the reader.
setItemType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.jms.JmsItemReader
Set the expected type of incoming message payloads.
setItemWriter(ItemWriter<? super O>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemWriter(ItemWriter<? super O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemWriter(ItemWriter<? super S>) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemWriter(ItemWriter<String>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
setJavaMailSender(JavaMailSender) - 类 中的方法org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
A JavaMailSender to be used to send messages in MimeMessageItemWriter.write(List).
setJdbcOperations(JdbcOperations) - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the JdbcOperations.
setJdbcOperations(JdbcOperations) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the JdbcOperations.
setJdbcTemplate(JdbcOperations) - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setJdbcTemplate(JdbcOperations) - 类 中的方法org.springframework.batch.sample.common.StagingItemProcessor
 
setJdbcTemplate(NamedParameterJdbcOperations) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the NamedParameterJdbcOperations.
setJmsTemplate(JmsOperations) - 类 中的方法org.springframework.batch.item.jms.JmsItemReader
Setter for JMS template.
setJmsTemplate(JmsOperations) - 类 中的方法org.springframework.batch.item.jms.JmsItemWriter
Setter for JMS template.
setJmsTemplate(JmsOperations) - 类 中的方法org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
Setter for jms template.
setJob(Job) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setJob(Job) - 类 中的方法org.springframework.batch.core.step.job.JobStep
The Job to delegate to in this step.
setJob(Job) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
The Job instance that can be manipulated (e.g. launched) in this utility.
setJobExecution(JobExecution) - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
setJobExecution(JobExecution) - 类 中的方法org.springframework.batch.core.jsr.JsrJobContextFactoryBean
Used to provide JobContext instances to batch artifacts that are not within the scope of a given step.
setJobExecutionIncrementer(DataFieldMaxValueIncrementer) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobExecution instances.
setJobExecutionListeners(Object[]) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
Addresses wrapping JobListener as needed to be used with the framework.
setJobExecutionListeners(JobExecutionListener[]) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
setJobExecutionListeners(JobExecutionListener[]) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Public setter for injecting JobExecutionListeners.
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.jsr.job.flow.JsrFlowJob
 
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobExplorer.
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobExplorer.
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
JobExplorer to use to query the job repository.
setJobExplorer(JobExplorer) - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequestHandler
An explorer that should be used to check for StepExecution completion.
setJobFactoryRef(String) - 类 中的方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
Convenience method for subclasses to set the job factory reference if it is available (null is fine, but the quality of error reports is better if it is available).
setJobIncrementer(DataFieldMaxValueIncrementer) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobInstance instances.
setJobInstance(JobInstance) - 类 中的方法org.springframework.batch.core.JobExecution
 
setJobLauncher(JobLauncher) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setJobLauncher(JobLauncher) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobLauncher.
setJobLauncher(JobLauncher) - 类 中的方法org.springframework.batch.core.step.job.JobStep
A JobLauncher is required to be able to run the enclosed Job.
setJobLauncher(JobLauncher) - 类 中的方法org.springframework.batch.sample.quartz.JobLauncherDetails
Public setter for the JobLauncher.
setJobLauncher(JobLauncher) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
A JobLauncher instance that can be used to launch jobs.
setJobLoader(JobLoader) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The job loader that will be used to load and manage jobs.
setJobLoader(JobLoader) - 类 中的方法org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A loader for the jobs that are going to be registered.
setJobLocator(JobLocator) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
JobLocator to find a job to run.
setJobLocator(JobLocator) - 类 中的方法org.springframework.batch.sample.quartz.JobLauncherDetails
Public setter for the JobLocator.
setJobParametersConverter(JobParametersConverter) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
Used to convert the Properties objects used by JSR-352 to the JobParameters objects used in Spring Batch.
setJobParametersConverter(JobParametersConverter) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobParametersConverter.
setJobParametersConverter(JobParametersConverter) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobParametersConverter.
setJobParametersExtractor(JobParametersExtractor) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setJobParametersExtractor(JobParametersExtractor) - 类 中的方法org.springframework.batch.core.step.job.JobStep
The JobParametersExtractor is used to extract JobParametersExtractor from the StepExecution to run the Job.
setJobParametersIncrementer(JobParametersIncrementer) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
setJobParametersIncrementer(JobParametersIncrementer) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Public setter for the JobParametersIncrementer.
setJobParametersIncrementer(JobParametersIncrementer) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobParametersIncrementer(JobParametersIncrementer) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobParametersIncrementer(JobParametersIncrementer) - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
 
setJobParametersValidator(JobParametersValidator) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
setJobParametersValidator(JobParametersValidator) - 类 中的方法org.springframework.batch.core.job.AbstractJob
A validator for job parameters.
setJobParametersValidator(JobParametersValidator) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobParametersValidator(JobParametersValidator) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobProperties(Properties) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds Job level properties to the context.
setJobRegistry(JobRegistry) - 类 中的方法org.springframework.batch.core.configuration.support.DefaultJobLoader
The JobRegistry to use for jobs created.
setJobRegistry(JobRegistry) - 类 中的方法org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Public setter for a JobRegistry to use for all the bind and unbind events.
setJobRegistry(JobRegistry) - 类 中的方法org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Injection setter for JobRegistry.
setJobRegistry(JobRegistry) - 类 中的方法org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A job registry that can be used to create a job loader (if none is provided).
setJobRegistry(ListableJobLocator) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the ListableJobLocator.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for JobRepository.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Public setter for the JobRepository that is needed to manage the state of the batch meta domain (jobs, steps, executions) during the life of a job.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.job.SimpleStepHandler
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the JobRepository.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The job repository that will be used to manage the persistence of the delegate step executions.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Public setter for JobRepository.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for JobRepository.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.test.JobLauncherTestUtils
The JobRepository to use for creating new JobExecution instances.
setJobRepository(JobRepository) - 类 中的方法org.springframework.batch.test.JobRepositoryTestUtils
 
setJsonObjectMarshaller(JsonObjectMarshaller<T>) - 类 中的方法org.springframework.batch.item.json.JsonFileItemWriter
Set the JsonObjectMarshaller to use to marshal object to json.
setJsonObjectReader(JsonObjectReader<T>) - 类 中的方法org.springframework.batch.item.json.JsonItemReader
Set the JsonObjectReader to use to read and map Json fragments to domain objects.
setKey(String) - 类 中的方法org.springframework.batch.core.launch.support.RunIdIncrementer
The name of the run id in the job parameters.
setKeyGenerator(KeyGenerator) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
A key generator that can be used to compare items with previously recorded items in a retry.
setKeyGenerator(KeyGenerator) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
The KeyGenerator to use to identify failed items across rollback.
setKeyGenerator(KeyGenerator) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
The KeyGenerator to use to identify failed items across rollback.
setKeyName(String) - 类 中的方法org.springframework.batch.core.partition.support.MultiResourcePartitioner
The name of the key for the file name in each ExecutionContext.
setKeyName(String) - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Public setter for the key name of a Long value in the JobParameters that will contain a commit interval.
setKeyName(String) - 类 中的方法org.springframework.batch.support.SystemPropertyInitializer
Set the key name for the System property that is created.
setKeys(String[]) - 类 中的方法org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setKeys(String[]) - 类 中的方法org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
setKeys(String[]) - 类 中的方法org.springframework.batch.core.step.job.DefaultJobParametersExtractor
The key names to pull out of the execution context or job parameters, if they exist.
setLast_name(String) - 类 中的方法org.springframework.batch.sample.domain.person.Person
Intentionally non-standard method name for testing purposes
setLastName(String) - 类 中的方法org.springframework.batch.core.test.football.Player
 
setLastName(String) - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
setLastName(String) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setLastUpdated(Date) - 类 中的方法org.springframework.batch.core.JobExecution
Set the last time this JobExecution was updated.
setLastUpdated(Date) - 类 中的方法org.springframework.batch.core.StepExecution
Set the time when the StepExecution was last updated before persisting
setLauncher(JobLauncher) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the JobLauncher.
setLimit(int) - 类 中的方法org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
The limit on the given exception type within a single context before it is rethrown.
setLimit(int) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
setLimit(int) - 类 中的方法org.springframework.batch.sample.loop.LimitDecider
 
setLineAggregator(LineAggregator<T>) - 类 中的方法org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the LineAggregator.
setLineEnding(String) - 类 中的方法org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
 
setLineItems(List<LineItem>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
setLineItems(List<LineItem>) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setLineMapper(LineMapper<T>) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Setter for line mapper.
setLineSeparator(String) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Public setter for the line separator.
setLinesToSkip(int) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Public setter for the number of lines to skip at the start of a file.
setLinesWritten(long) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setLineTokenizer(LineTokenizer) - 类 中的方法org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setListeners(Object[]) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
The listeners to inject into the Step.
setListeners(List<? extends RetryProcessListener>) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryProcessListener
Public setter for the RetryProcessListener's.
setListeners(List<? extends RetryReadListener>) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryReadListener
Public setter for the RetryReadListener's.
setListeners(List<? extends RetryWriteListener>) - 类 中的方法org.springframework.batch.core.listener.CompositeRetryWriteListener
Public setter for the RetryWriteListener's.
setListeners(List<? extends ChunkListener>) - 类 中的方法org.springframework.batch.core.listener.CompositeChunkListener
Public setter for the listeners.
setListeners(List<? extends ItemProcessListener<? super T, ? super S>>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemProcessListener
Public setter for the listeners.
setListeners(List<? extends ItemReadListener<? super T>>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemReadListener
Public setter for the listeners.
setListeners(List<? extends ItemWriteListener<? super S>>) - 类 中的方法org.springframework.batch.core.listener.CompositeItemWriteListener
Public setter for the listeners.
setListeners(List<? extends JobExecutionListener>) - 类 中的方法org.springframework.batch.core.listener.CompositeJobExecutionListener
Public setter for the listeners.
setListeners(List<? extends SkipListener<? super T, ? super S>>) - 类 中的方法org.springframework.batch.core.listener.CompositeSkipListener
Public setter for the listeners.
setListeners(List<? extends StepListener>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - 类 中的方法org.springframework.batch.core.listener.MulticasterBatchListener
Register each of the objects as listeners.
setListeners(List<? extends StepListener>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProvider
Register some StepListeners with the handler.
setListeners(StepExecutionListener[]) - 类 中的方法org.springframework.batch.core.listener.CompositeStepExecutionListener
Public setter for the listeners.
setListeners(StepListener[]) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The listeners to inject into the Step.
setListeners(RepeatListener[]) - 类 中的方法org.springframework.batch.repeat.listener.CompositeRepeatListener
Public setter for the listeners.
setListeners(RepeatListener[]) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Set the listeners for this template, registering them for callbacks at appropriate times in the iteration.
setListeners(RetryListener[]) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
setLobHandler(LobHandler) - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
The lob handler to use when saving ExecutionContext instances.
setLobHandler(LobHandler) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
setLobHandler(LobHandler) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
A special handler for large objects.
setLocale(Locale) - 类 中的方法org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the locale.
setLoginTimeout(int) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
setLogWriter(PrintWriter) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
setMailErrorHandler(MailErrorHandler) - 类 中的方法org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
The handler for failed messages.
setMailErrorHandler(MailErrorHandler) - 类 中的方法org.springframework.batch.item.mail.SimpleMailMessageItemWriter
The handler for failed messages.
setMailSender(MailSender) - 类 中的方法org.springframework.batch.item.mail.SimpleMailMessageItemWriter
A MailSender to be used to send messages in SimpleMailMessageItemWriter.write(List).
setMapper(ObjectMapper) - 类 中的方法org.springframework.batch.item.json.JacksonJsonObjectReader
Set the object mapper to use to map Json objects to domain objects.
setMapper(Gson) - 类 中的方法org.springframework.batch.item.json.GsonJsonObjectReader
Set the object mapper to use to map Json objects to domain objects.
setMapping(Map<String, Integer>) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
Supply the ExitCodeMappings
setMappings(Map<Object, ExitStatus>) - 类 中的方法org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
setMarshaller(Marshaller) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set Object to XML marshaller.
setMatchStatement(String) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
An optional match fragment of the cypher query.
setMaxCount(int) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
Setter for maximum value of count before termination.
setMaximumLength(int) - 类 中的方法org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the maximum length of the formatted string.
setMaxItemCount(int) - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The maximum index of the items to be read.
setMaxMessageLength(int) - 类 中的方法org.springframework.batch.item.mail.DefaultMailErrorHandler
The limit for the size of message that will be copied to the exception message.
setMaxRows(int) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Sets the limit for the maximum number of rows that any ResultSet object can contain to the given number.
setMaxSkipsOnRead(int) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
setMaxVarCharLength(int) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the length of long string columns in database.
setMaxWaitTimeouts(int) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
setMessageSource(MessageSource<?>) - 类 中的方法org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
 
setMessagingOperations(MessagingTemplate) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setMessagingOperations(MessagingTemplate) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
A pre-configured gateway for sending and receiving messages to the remote workers.
setMetaDataMap(Map<String, String>) - 类 中的方法org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setMethodName(String) - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
Specifies what method on the repository to call.
setMethodName(String) - 类 中的方法org.springframework.batch.item.data.RepositoryItemWriter
Specifies what method on the repository to call.
setMiddleName(String) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setMillisToSleep(long) - 类 中的方法org.springframework.batch.core.test.timeout.SleepingItemProcessor
 
setMillisToSleep(long) - 类 中的方法org.springframework.batch.core.test.timeout.SleepingTasklet
 
setMinimumLength(int) - 类 中的方法org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the minimum length of the formatted string.
setMoo(int) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setName(String) - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
The name of the flow that is created by this factory.
setName(String) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setName(String) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Set the name property.
setName(String) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setName(String) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
The name of the state
setName(String) - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
Public setter for the name property.
setName(String) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Set the name property.
setName(String) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setName(String) - 类 中的方法org.springframework.batch.item.ItemStreamSupport
The name of the component which will be used as a stem for keys in the ExecutionContext.
setName(String) - 类 中的方法org.springframework.batch.item.util.ExecutionContextUserSupport
 
setName(String) - 类 中的方法org.springframework.batch.sample.domain.mail.User
 
setName(String) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setName(String) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
setName(String) - 类 中的方法org.springframework.batch.sample.domain.person.Child
 
setName(String) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
setName(String) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
setName(String) - 类 中的方法org.springframework.batch.sample.validation.domain.Person
 
setNames(String...) - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
Setter for column names.
setNames(String[]) - 类 中的方法org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
setNoRollbackExceptionClasses(Collection<Class<? extends Throwable>>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Exception classes that may not cause a rollback if encountered in the right place.
setNoRollbackExceptionClasses(Collection<Class<? extends Throwable>>) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Exception classes that are candidates for no rollback.
setNotificationPublisher(NotificationPublisher) - 类 中的方法org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
Injection setter.
setNumberFormat(NumberFormat) - 类 中的方法org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for the NumberFormat.
setNumberFormat(NumberFormat) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
The NumberFormat to use for parsing numbers.
setNumberFormat(NumberFormat) - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The NumberFormat to use for parsing numbers.
setObjectMapper(ObjectMapper) - 类 中的方法org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
setObjectMapper(ObjectMapper) - 类 中的方法org.springframework.batch.item.json.JacksonJsonObjectMarshaller
Set the ObjectMapper to use.
setOpponent(String) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setOpponent(String) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setOptionalKeys(String[]) - 类 中的方法org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are optional in the parameters.
setOrder(int) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The order to start up and shutdown.
setOrder(int) - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
 
setOrderByStatement(String) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
A list of properties to order the results by.
setOrderDate(Date) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setOrderId(long) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setOutputKeyName(String) - 类 中的方法org.springframework.batch.sample.common.OutputFileListener
 
setOverwriteOutput(boolean) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set "overwrite" flag for the output file.
setPageSize(int) - 类 中的方法org.springframework.batch.item.data.AbstractPaginatedDataItemReader
The number of items to be read with each page.
setPageSize(int) - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
 
setPageSize(int) - 类 中的方法org.springframework.batch.item.database.AbstractPagingItemReader
The number of rows to retrieve at a time.
setParameters(List<?>) - 类 中的方法org.springframework.batch.item.database.support.ListPreparedStatementSetter
已过时。
In favor of the constructor
setParameters(SqlParameter[]) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Add one or more declared parameters.
setParameterValues(List<Object>) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
List of values to be substituted in for each of the parameters in the query.
setParameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
Optional parameters to be used in the cypher query.
setParameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
The parameter values to apply to a query (map of name:value).
setParameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
The parameter values to apply to a query (map of name:value).
setParameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
The parameter values to be used for the query execution.
setParameterValues(Map<String, Object>) - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
The parameter values to be used for the query execution.
setPartitionAnalyzer(PartitionAnalyzer) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionDataQueue(Queue<Serializable>) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitioner(Partitioner) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setPartitioner(Partitioner) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The Partitioner that will be used to generate step execution meta data for the target step.
setPartitionHandler(PartitionHandler) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setPartitionHandler(PartitionHandler) - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
A PartitionHandler which can send out step executions for remote processing and bring back the results.
setPartitionLock(ReentrantLock) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Used to coordinate access to the partition queue between the PartitionCollector and AbstractPartitionAnalyzer
setPartitionLock(ReentrantLock) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionLock(ReentrantLock) - 类 中的方法org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
setPartitionMapper(PartitionMapper) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionPlan(PartitionPlan) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPartitionProperties(Properties[]) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPartitionQueue(Queue<Serializable>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setPartitionReducer(PartitionReducer) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setPartitionReducer(PartitionReducer) - 类 中的方法org.springframework.batch.core.jsr.step.PartitionStep
 
setPartitions(int) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setPartitions(int) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPartitions(int) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionsOverride(boolean) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPassingTd(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setPassingTd(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setPassingTd(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setPassingTd(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setPassingYards(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setPassingYards(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setPassingYards(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setPassingYards(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setPath(String) - 类 中的方法org.springframework.batch.sample.common.OutputFileListener
 
setPattern(Pattern) - 类 中的方法org.springframework.batch.item.file.transform.RegexLineTokenizer
Sets the regex pattern to use.
setPaymentDesc(String) - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
setPaymentId(String) - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
setPerOunceRate(double) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
setPersistentUserData(Serializable) - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
setPerUnitOunces(double) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setPhase(int) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
setPlayerDao(PlayerDao) - 类 中的方法org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
setPolicies(CompletionPolicy[]) - 类 中的方法org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Setter for the policies.
setPolicyMap(Map<Class<? extends Throwable>, SkipPolicy>) - 类 中的方法org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Setter for policy map.
setPollingInterval(int) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPollInterval(long) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
How often to poll the job repository for the status of the slaves.
setPoo(int) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setPosition(String) - 类 中的方法org.springframework.batch.core.test.football.Player
 
setPosition(String) - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
setPreparedStatementSetter(PreparedStatementSetter) - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
Set the PreparedStatementSetter to use if any parameter values that need to be set in the supplied query.
setPreparedStatementSetter(PreparedStatementSetter) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Set the PreparedStatementSetter to use if any parameter values that need to be set in the supplied query.
setPrice(double) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setPrice(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setPrice(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
setProcedureName(String) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Set the SQL statement to be used when creating the cursor.
setProcessorTransactional(boolean) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
setProcessorTransactional(boolean) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
Flag to say that the ItemProcessor is transactional (defaults to true).
setProcessorTransactional(Boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Flag to signal that the processor is transactional, in which case it should be called for every item in every transaction.
setProcessSkipCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Set the number of records skipped during processing.
setProcessSkipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setPropagation(Propagation) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setPropagation(Propagation) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setProperties(Properties) - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
setProperty(String, String) - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
setProperty(String, String) - 接口 中的方法org.springframework.batch.sample.launch.JobLoader
 
setPropertyContext(BatchPropertyContext) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPrototypeBeanName(String) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
The bean name (id) for an object that can be populated from the field set that will be passed into BeanWrapperFieldSetMapper.mapFieldSet(FieldSet).
setProxyTargetClass(boolean) - 类 中的方法org.springframework.batch.core.scope.BatchScopeSupport
Flag to indicate that proxies should use dynamic subclassing.
setQuantity(int) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setQuantity(int) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setQuantity(long) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
setQuery(String) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
A JSON formatted MongoDB query.
setQuery(Query) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
A Mongo Query to be used.
setQueryName(String) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
A query name for an externalized query.
setQueryName(String) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryName(String) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
A query name for an externalized query.
setQueryProvider(HibernateQueryProvider<? extends T>) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryProvider(HibernateQueryProvider<? extends T>) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
A query provider.
setQueryProvider(HibernateQueryProvider<T>) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
A query provider.
setQueryProvider(JpaQueryProvider) - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
setQueryProvider(PagingQueryProvider) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
setQueryString(String) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
A query string in HQL.
setQueryString(String) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryString(String) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
A query string in HQL.
setQueryString(String) - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
 
setQueryTimeout(int) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Sets the number of seconds the driver will wait for a Statement object to execute to the given number of seconds.
setQuoteCharacter(char) - 类 中的方法org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Public setter for the quoteCharacter.
setQuoteCharacter(String) - 类 中的方法org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the quoteCharacter.
setReadCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the current number of read items for this execution
setReader(GeneratingTradeItemReader) - 类 中的方法org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
setReadSkipCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Set the number of records skipped on read
setReceptions(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setReceptions(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setReceptions(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setReceptions(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setReceptionYards(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setReceptionYards(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setReceptionYards(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setReceptionYards(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setRecordMapper(RecordMapper<T>) - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
Setter for object mapper.
setRecordSeparatorPolicy(RecordSeparatorPolicy) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Public setter for the recordSeparatorPolicy.
setRecordsToSkip(int) - 类 中的方法org.springframework.batch.item.ldif.LdifReader
Public setter for the number of lines to skip at the start of a file.
setRecordsToSkip(int) - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
Public setter for the number of lines to skip at the start of a file.
setRefCursorPosition(int) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Set the parameter position of the REF CURSOR.
setReflectionProvider(ReflectionProvider) - 类 中的方法org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
 
setRegex(String) - 类 中的方法org.springframework.batch.item.file.transform.RegexLineTokenizer
Sets the regular expression to use.
setRegistered(boolean) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setRegistrationId(long) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setRegistry(ListableJobLocator) - 类 中的方法org.springframework.batch.sample.launch.DefaultJobLoader
 
setRepeatOperations(RepeatOperations) - 类 中的方法org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Setter for the RepeatOperations.
setReplyChannel(PollableChannel) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setReplyChannel(PollableChannel) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
setRepository(CrudRepository<T, ?>) - 类 中的方法org.springframework.batch.item.data.RepositoryItemWriter
Set the CrudRepository implementation for persistence
setRepository(PagingAndSortingRepository<?, ?>) - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
The PagingAndSortingRepository implementation used to read input from.
setRepositoryFactory(MapJobRepositoryFactoryBean) - 类 中的方法org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
The repository factory that can be used to create daos for the explorer.
setRequiredKeys(String[]) - 类 中的方法org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are required in the parameters.
setResource(Resource) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
Public setter for the input resource.
setResource(Resource) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
Prototype for output resources.
setResource(Resource) - 接口 中的方法org.springframework.batch.item.file.ResourceAwareItemReaderItemStream
 
setResource(Resource) - 接口 中的方法org.springframework.batch.item.file.ResourceAwareItemWriterItemStream
 
setResource(Resource) - 类 中的方法org.springframework.batch.item.json.JsonItemReader
 
setResource(Resource) - 类 中的方法org.springframework.batch.item.ldif.LdifReader
Establishes the resource that will be used as the input for the LdifReader.
setResource(Resource) - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
 
setResource(Resource) - 接口 中的方法org.springframework.batch.item.ResourceAware
 
setResource(Resource) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Setter for resource.
setResource(Resource) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
setResource(Resource) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set output file.
setResources(Resource[]) - 类 中的方法org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
A set of resources to load using a GenericApplicationContextFactory.
setResources(Resource[]) - 类 中的方法org.springframework.batch.core.partition.support.MultiResourcePartitioner
The resources to assign to each partition.
setResources(Resource[]) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
 
setResources(Resource[]) - 类 中的方法org.springframework.batch.item.file.ResourcesItemReader
The resources to serve up as items.
setResourceSuffixCreator(ResourceSuffixCreator) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
Allows customization of the suffix of the created resources based on the index.
setRestartable(boolean) - 类 中的方法org.springframework.batch.core.job.AbstractJob
Boolean flag to prevent categorically a job from restarting, even if it has failed previously.
setRestartable(boolean) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setRestartable(Boolean) - 类 中的方法org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
setRestartable(Boolean) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for exception classes that will retry the item when raised.
setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the retryable exceptions classifier map (from throwable class to boolean, true is retryable).
setRetryContextCache(RetryContextCache) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setRetryContextCache(RetryContextCache) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Override the default retry context cache for retry of chunk processing.
setRetryContextCache(RetryContextCache) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
setRetryLimit(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the retry limit.
setRetryLimit(int) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the retry limit.
setRetryListeners(RetryListener...) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the RetryListeners.
setRetryListeners(RetryListener...) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the RetryListeners.
setRetryPolicy(RetryPolicy) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
A retry policy to apply when exceptions occur.
setRetryPolicy(RetryPolicy) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Setter for the retry policy.
setRetryPolicy(RetryPolicy) - 类 中的方法org.springframework.batch.core.step.item.BatchRetryTemplate
 
setReturnStatement(String) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
The return statement of the cypher query.
setRollbackClassifier(Classifier<Throwable, Boolean>) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
setRollbackClassifier(Classifier<Throwable, Boolean>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A classifier that can distinguish between exceptions that cause rollback (return true) or not (return false).
setRollbackClassifier(Classifier<Throwable, Boolean>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProvider
Classifier to determine whether exceptions have been marked as no-rollback (as opposed to skippable).
setRollbackCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Setter for number of rollbacks for this execution
setRootElementAttributes(Map<String, String>) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set the root element attributes to be written.
setRootTagName(String) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set the tag name of the root element.
setRowMapper(RowMapper<T>) - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
Set the RowMapper to be used for all calls to read().
setRowMapper(RowMapper<T>) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
The row mapper implementation to be used by this reader.
setRowMapper(RowMapper<T>) - 类 中的方法org.springframework.batch.item.database.StoredProcedureItemReader
Set the RowMapper to be used for all calls to read().
setRushes(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setRushes(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setRushes(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setRushes(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setRushYards(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setRushYards(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setRushYards(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setRushYards(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setSaveState(boolean) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
Set the boolean indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
Indicates that the state of the reader will be saved after each commit.
setSaveState(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Set the flag indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Set the flag that determines whether to save internal data for ExecutionContext.
setSaveState(boolean) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
 
setScript(Resource) - 类 中的方法org.springframework.batch.item.support.ScriptItemProcessor
Sets the Resource location of the script to use.
setScriptEvaluator(ScriptEvaluator) - 类 中的方法org.springframework.batch.item.support.ScriptItemProcessor
Provides the ability to set a custom ScriptEvaluator implementation.
setScriptSource(String, String) - 类 中的方法org.springframework.batch.item.support.ScriptItemProcessor
Sets the provided String as the script source code to use.
setSelectClause(String) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSelectClause(String) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSeparator(String) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
setSerializer(ExecutionContextSerializer) - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
A custom implementation of the ExecutionContextSerializer.
setSerializer(ExecutionContextSerializer) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
Setter for Serializer implementation
setSerializer(ExecutionContextSerializer) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
A custom implementation of the ExecutionContextSerializer.
setSession(Session) - 类 中的方法org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
setSession(Session) - 接口 中的方法org.springframework.batch.item.database.orm.HibernateQueryProvider
Inject a Session that can be used as a factory for queries.
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
The Hibernate SessionFactory to use the create a session.
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
 
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.HibernateItemWriter
Set the Hibernate SessionFactory to be used internally.
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
The Hibernate SessionFactory to use the create a session.
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
Establish the session factory for the reader.
setSessionFactory(SessionFactory) - 类 中的方法org.springframework.batch.item.data.Neo4jItemWriter
Establish the session factory that will be used to create Session instances for interacting with Neo4j.
setShipper(Shipper) - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
setShipperId(String) - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
setShipping(ShippingInfo) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setShippingAddress(Address) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setShippingInfo(String) - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
setShippingMapper(FieldSetMapper<ShippingInfo>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setShippingPrice(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setShippingTypeId(String) - 类 中的方法org.springframework.batch.sample.domain.order.ShippingInfo
 
setShortContextLength(int) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
The maximum size that an execution context can have and still be stored completely in short form in the column SHORT_CONTEXT.
setShouldDeleteIfEmpty(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that the target file should be deleted if no lines have been written (other than header and footer) on close.
setShouldDeleteIfEmpty(boolean) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Flag to indicate that the target file should be deleted if no items have been written (other than header and footer) on close.
setShouldDeleteIfExists(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that the target file should be deleted if it already exists, otherwise it will be created.
setSingleton(boolean) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the singleton flag.
setSkipLimit(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for a limit that determines skip policy.
setSkipLimit(int) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
A limit that determines skip policy.
setSkipLimit(int) - 类 中的方法org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The absolute number of skips (of skippable exceptions) that can be tolerated before a failure.
setSkippableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for exception classes that when raised won't crash the job but will result in transaction rollback and the item which handling caused the exception will be skipped.
setSkippableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Exception classes that when raised won't crash the job but will result in the item which handling caused the exception being skipped.
setSkippableExceptionClassifier(Classifier<Throwable, Boolean>) - 类 中的方法org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The classifier that will be used to decide on skippability.
setSkippableExceptionMap(Map<Class<? extends Throwable>, Boolean>) - 类 中的方法org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Set up the classifier through a convenient map from throwable class to boolean (true if skippable).
setSkippedLinesCallback(LineCallbackHandler) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
 
setSkippedRecordsCallback(RecordCallbackHandler) - 类 中的方法org.springframework.batch.item.ldif.LdifReader
RecordCallbackHandler implementations can be used to take action on skipped records.
setSkippedRecordsCallback(RecordCallbackHandler) - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
RecordCallbackHandler implementations can be used to take action on skipped records.
setSkipPolicies(SkipPolicy[]) - 类 中的方法org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
setSkipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for a skip policy.
setSkipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
setSkipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
A SkipPolicy that determines the outcome of an exception when processing an item.
setSkipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProvider
The policy that determines whether exceptions can be skipped on read.
setSort(Map<String, Sort.Direction>) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
Map of property names/Sort.Direction values to sort the input by.
setSort(Map<String, Sort.Direction>) - 类 中的方法org.springframework.batch.item.data.RepositoryItemReader
Provides ordering of the results so that order is maintained between paged queries
setSortKey(String) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSortKeys(Map<String, Order>) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSortKeys(Map<String, Order>) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSql(String) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the query string to execute on write.
setSql(String) - 类 中的方法org.springframework.batch.item.database.JdbcCursorItemReader
Set the SQL statement to be used when creating the cursor.
setSqlQuery(String) - 类 中的方法org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
setSqlQuery(String) - 类 中的方法org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
setStartLimit(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
The number of times that the step should be allowed to start
setStartLimit(int) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Public setter for the startLimit.
setStartLimit(int) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the start limit for the step.
setStartLimit(Integer) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setStartStatement(String) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
The start segment of the cypher query.
setStartTime(Date) - 类 中的方法org.springframework.batch.core.JobExecution
 
setStartTime(Date) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the time this execution started
setState(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
setStatelessSession(StatelessSession) - 类 中的方法org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
setStatelessSession(StatelessSession) - 接口 中的方法org.springframework.batch.item.database.orm.HibernateQueryProvider
Inject a StatelessSession that can be used as a factory for queries.
setStateTransitionComparator(Comparator<StateTransition>) - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
setStateTransitionComparator(Comparator<StateTransition>) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
setStateTransitions(List<StateTransition>) - 类 中的方法org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
The raw state transitions for the flow.
setStateTransitions(List<StateTransition>) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
Public setter for the stateTransitions.
setStatus(BatchStatus) - 类 中的方法org.springframework.batch.core.JobExecution
Set the value of the status field.
setStatus(BatchStatus) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the current status of this step
setStatuses(String[]) - 类 中的方法org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setStep(Step) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setStep(Step) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setStep(Step) - 类 中的方法org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the Step that will be used to execute the partitioned StepExecution.
setStep(TaskletStep) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The local step that is to be converted to a remote chunk master.
setStepArtifactProperties(Map<String, Map<String, Properties>>) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds Step artifact properties to the context.
setStepChunkCompletionPolicy(Object) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a CheckpointAlgorithm in a CheckpointAlgorithmAdapter if required for consumption by the rest of the framework.
setStepContributionSource(StepContributionSource) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
A source of StepContribution instances coming back from remote workers.
setStepExecutionAggregator(StepExecutionAggregator) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setStepExecutionAggregator(StepExecutionAggregator) - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
A StepExecutionAggregator that can aggregate step executions when they come back from the handler.
setStepExecutionIncrementer(DataFieldMaxValueIncrementer) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
setStepExecutionListeners(StepExecutionListener[]) - 类 中的方法org.springframework.batch.core.step.AbstractStep
Register each of the objects as listeners.
setStepExecutionSplitter(StepExecutionSplitter) - 类 中的方法org.springframework.batch.core.partition.support.PartitionStep
Public setter for mandatory property StepExecutionSplitter.
setStepItemProcessor(Object) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a ItemProcessor in a ItemProcessorAdapter if required for consumption by the rest of the framework.
setStepItemReader(Object) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a ItemReader in a ItemReaderAdapter if required for consumption by the rest of the framework.
setStepItemWriter(Object) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a ItemWriter in a ItemWriterAdapter if required for consumption by the rest of the framework.
setStepLocator(StepLocator) - 类 中的方法org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepLocator(StepLocator) - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequestHandler
Used to locate a Step to execute for each request.
setStepName(String) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The name of the target step that will be executed across the partitions.
setStepName(String) - 类 中的方法org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepName(String) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
The name of the Step that will be used to execute the partitioned StepExecution.
setStepOperations(RepeatOperations) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the stepOperations.
setStepOperations(RepeatOperations) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
The RepeatOperations to use for the outer loop of the batch processing.
setStepProperties(String, Properties) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Convenience method to set step level properties.
setStepProperties(Map<String, Properties>) - 类 中的方法org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds Step level properties to the context.
setStepRegistry(StepRegistry) - 类 中的方法org.springframework.batch.core.configuration.support.DefaultJobLoader
The StepRegistry to use for the steps of created jobs.
setSteps(List<Step>) - 类 中的方法org.springframework.batch.core.job.SimpleJob
Public setter for the steps in this job.
setStepTasklet(Object) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a Batchlet in a BatchletAdapter if required for consumption by the rest of the framework.
setStreams(ItemStream[]) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
The streams to inject into the Step.
setStreams(ItemStream[]) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The streams to inject into the Step.
setStreams(ItemStream[]) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the streams for callbacks at the appropriate time in the step.
setStreams(ItemStream[]) - 类 中的方法org.springframework.batch.item.support.CompositeItemStream
Public setter for the ItemStreams.
setStrict(boolean) - 类 中的方法org.springframework.batch.core.listener.ExecutionContextPromotionListener
If set to TRUE, the listener will throw an exception if any 'key' is not found in the Step ExecutionContext.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
In strict mode the reader will throw an exception on MultiResourceItemReader.open(org.springframework.batch.item.ExecutionContext) if there are no resources to read.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.file.FlatFileItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the 'strict' property.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
In strict mode the reader will throw an exception on MultiResourceItemReader.open(org.springframework.batch.item.ExecutionContext) if there are no resources to read.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
Public setter for the strict flag.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.json.JsonItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.ldif.LdifReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.ldif.MappingLdifReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setSubjectsToFail(List<String>) - 类 中的方法org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
setSuffix(String) - 类 中的方法org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Lines ending in this terminator String signal the end of a record.
setSystemExiter(SystemExiter) - 类 中的方法org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the SystemExiter.
setSystemProcessExitCodeMapper(SystemProcessExitCodeMapper) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setTable(String) - 类 中的方法org.springframework.batch.sample.common.ColumnRangePartitioner
The name of the SQL table the data are in.
setTablePrefix(String) - 类 中的方法org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTablePrefix(String) - 类 中的方法org.springframework.batch.core.jsr.JsrJobParametersConverter
The table prefix used in the current JobRepository
setTablePrefix(String) - 类 中的方法org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Public setter for the table prefix property.
setTablePrefix(String) - 类 中的方法org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTargetMethod(String) - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetObject(Object) - 类 中的方法org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
The type of object to be returned for each AbstractItemCountingItemStreamItemReader.read() call.
setTargetType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the type of bean to create instead of using a prototype bean.
setTargetType(Class<T>) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
The object type to be returned from each call to AbstractItemCountingItemStreamItemReader.read()
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the TaskExecutor.
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.state.SplitState
Public setter for the taskExecutor.
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the TaskExecutor.
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the TaskExecutor that is used to farm out step executions to multiple threads.
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the TaskExecutor.
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Sets the task executor that will be used to execute the system command NB!
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.integration.async.AsyncItemProcessor
The TaskExecutor to use to allow the item processing to proceed in the background.
setTaskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Setter for task executor to be used to run the individual item callbacks.
setTasklet(Tasklet) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
A preconfigured Tasklet to use.
setTasklet(Tasklet) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the Tasklet.
setTeam(String) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setTeam(String) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setTemplate(GemfireTemplate) - 类 中的方法org.springframework.batch.item.data.GemfireItemWriter
 
setTemplate(MongoOperations) - 类 中的方法org.springframework.batch.item.data.MongoItemReader
Used to perform operations against the MongoDB instance.
setTemplate(MongoOperations) - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
Set the MongoOperations to be used to save items to be written.
setTerminateOnly() - 类 中的方法org.springframework.batch.core.StepExecution
Set a flag that will signal to an execution environment that this execution (and its surrounding job) wishes to exit.
setTerminateOnly() - 类 中的方法org.springframework.batch.repeat.context.RepeatContextSupport
 
setTerminateOnly() - 接口 中的方法org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete abnormally, independent of the current CompletionPolicy.
setTerminationCheckInterval(long) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
The time interval how often the tasklet will check for termination status.
setThreads(int) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setThreads(int) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setThresholds(Map<Class<? extends Throwable>, Integer>) - 类 中的方法org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
A map from exception classes to a threshold value of type Integer.
setThrottleLimit(int) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the throttle limit.
setThrottleLimit(int) - 类 中的方法org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Public setter for the throttle limit.
setThrottleLimit(long) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
Public setter for the throttle limit.
setThrottleLimit(Integer) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the throttle limit.
setThrowExceptionOnRecordNumber(int) - 类 中的方法org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
setTimeout(long) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Timeout in milliseconds.
setTimeout(long) - 类 中的方法org.springframework.batch.integration.partition.MessageChannelPartitionHandler
When using job repository polling, the time limit to wait.
setTimeout(Integer) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setTitle(String) - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
setTokenizers(Map<String, LineTokenizer>) - 类 中的方法org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
setTokenizers(Map<String, LineTokenizer>) - 类 中的方法org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
setTotalItems(int) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setTotalLines(int) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setTotalPrice(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
setTotalPrice(BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
setTotalTd(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setTotalTd(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setTotalTd(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setTotalTd(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setTransacted(boolean) - 类 中的方法org.springframework.batch.item.database.JpaPagingItemReader
By default (true) the EntityTransaction will be started and committed around the read.
setTransactional(boolean) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that writing to the buffer should be delayed if a transaction is active.
setTransactional(boolean) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Flag to indicate that writes should be deferred to the end of a transaction if present.
setTransactionAttribute(TransactionAttribute) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the TransactionAttribute.
setTransactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setTransactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setTransactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setTransactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the PlatformTransactionManager.
setTransactionTimeout(int) - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setTransactionTimeout(int) - 类 中的方法org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The timeout for an individual transaction in the step.
setTransientUserData(Object) - 类 中的方法org.springframework.batch.core.jsr.JsrJobContext
 
setTransientUserData(Object) - 类 中的方法org.springframework.batch.core.jsr.JsrStepContext
 
setUnmarshaller(Unmarshaller) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
 
setUpOutputFile(File, boolean, boolean) - 类 中的静态方法org.springframework.batch.item.util.FileUtils
已过时。
use the version with explicit append parameter instead. Here append=false is assumed.
setUpOutputFile(File, boolean, boolean, boolean) - 类 中的静态方法org.springframework.batch.item.util.FileUtils
Set up output file for batch processing.
setUseAllParentParameters(boolean) - 类 中的方法org.springframework.batch.core.step.job.DefaultJobParametersExtractor
setter to support switching off all parent parameters
setUseParent(boolean) - 类 中的方法org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Flag to indicate the the exception counters should be shared between sibling contexts in a nested batch.
setUseParent(boolean) - 类 中的方法org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Flag to indicate the the exception counters should be shared between sibling contexts in a nested batch (i.e. inner loop).
setUseParent(boolean) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
Flag to indicate whether the count is at the level of the parent context, or just local to the context.
setUserData(Object) - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
setUseSharedExtendedConnection(boolean) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Indicate whether the connection used for the cursor should be used by all other processing thus sharing the same transaction.
setUseStatelessSession(boolean) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
Can be set only in uninitialized state.
setUseStatelessSession(boolean) - 类 中的方法org.springframework.batch.item.database.HibernateItemReaderHelper
Can be set only in uninitialized state.
setUseStatelessSession(boolean) - 类 中的方法org.springframework.batch.item.database.HibernatePagingItemReader
Can be set only in uninitialized state.
setValidateTransactionState(boolean) - 类 中的方法org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Flag to determine whether to check for an existing transaction when a JobExecution is created.
setValidating(boolean) - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Set whether to use XML validation.
setValidationFailure(int) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeProcessor
Public setter for the the index on which failure should occur.
setValidator(Validator<? super T>) - 类 中的方法org.springframework.batch.item.validator.ValidatingItemProcessor
Set the validator used to validate each item.
setValidator(Validator) - 类 中的方法org.springframework.batch.item.validator.SpringValidator
 
setValidators(List<JobParametersValidator>) - 类 中的方法org.springframework.batch.core.job.CompositeJobParametersValidator
Public setter for the validators
setValues(PreparedStatement) - 类 中的方法org.springframework.batch.item.database.support.ListPreparedStatementSetter
 
setValues(Map<String, Object>, PreparedStatement) - 类 中的方法org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
setValues(CustomerCredit, PreparedStatement) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
setValues(T, PreparedStatement) - 接口 中的方法org.springframework.batch.item.database.ItemPreparedStatementSetter
Set parameter values on the given PreparedStatement as determined from the provided item.
setVerifyCursorPosition(boolean) - 类 中的方法org.springframework.batch.item.database.AbstractCursorItemReader
Allow verification of cursor position after current row is processed by RowMapper or RowCallbackHandler.
setVersion(long) - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
setVersion(Integer) - 类 中的方法org.springframework.batch.core.Entity
Public setter for the version needed only by repository methods.
setVersion(String) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Set XML version to be used for output XML.
setVip(boolean) - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
setWeek(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setWeek(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setWhereClause(String) - 类 中的方法org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setWhereClause(String) - 类 中的方法org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setWhereStatement(String) - 类 中的方法org.springframework.batch.item.data.AbstractNeo4jItemReader
An optional where fragment of the cypher query.
setWorkingDirectory(String) - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setWriteCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Sets the current number of written items for this execution
setWriteSkipCount(int) - 类 中的方法org.springframework.batch.core.StepExecution
Set the number of records skipped on write
setWriteSkipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setXmlInputFactory(XMLInputFactory) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemReader
Set the XMLInputFactory.
setYear(int) - 类 中的方法org.springframework.batch.core.test.football.Game
 
setYear(int) - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
setYear(int) - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
setYear(int) - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
setZipCode(String) - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
Shipper - org.springframework.batch.sample.domain.order.internal.xml中的类
An XML shipper.
Shipper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
SHIPPER_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
SHIPPING_PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
SHIPPING_TYPE_ID_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
ShippingFieldSetMapper - org.springframework.batch.sample.domain.order.internal.mapper中的类
 
ShippingFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
ShippingInfo - org.springframework.batch.sample.domain.order中的类
 
ShippingInfo() - 类 的构造器org.springframework.batch.sample.domain.order.ShippingInfo
 
shouldClose(Connection) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
shouldDeleteIfEmpty(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true, once the step is complete, if the resource previously provided is empty, it will be deleted.
shouldDeleteIfEmpty(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true, once the step is complete, if the resource previously provided is empty, it will be deleted.
shouldDeleteIfEmpty(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Flag to indicate that the output file should be deleted if no results were written to it.
shouldDeleteIfExists - 类 中的变量org.springframework.batch.item.support.AbstractFileItemWriter
 
shouldDeleteIfExists(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true, upon the start of the step, if the resource already exists, it will be deleted and recreated.
shouldDeleteIfExists(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true, upon the start of the step, if the resource already exists, it will be deleted and recreated.
shouldGenerateId() - 类 中的方法org.springframework.batch.core.configuration.xml.InlineFlowParser
 
shouldGenerateIdAsFallback() - 类 中的方法org.springframework.batch.core.jsr.configuration.xml.BatchParser
 
shouldSkip(Throwable, int) - 类 中的方法org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - 类 中的方法org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
shouldSkip(Throwable, int) - 类 中的方法org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Consult the classifier and find a delegate policy, and then use that to determine the outcome.
shouldSkip(Throwable, int) - 类 中的方法org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Given the provided exception and skip count, determine whether or not processing should continue for the given exception.
shouldSkip(Throwable, int) - 类 中的方法org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - 接口 中的方法org.springframework.batch.core.step.skip.SkipPolicy
Returns true or false, indicating whether or not processing should continue with the given throwable.
shouldStart(StepExecution, JobExecution, Step) - 类 中的方法org.springframework.batch.core.job.SimpleStepHandler
Given a step and configuration, return true if the step should start, false if it should not, and throw an exception if the job should finish.
shouldStart(StepExecution, JobExecution, Step) - 类 中的方法org.springframework.batch.core.jsr.job.JsrStepHandler
Given a step and configuration, return true if the step should start, false if it should not, and throw an exception if the job should finish.
SimpleBatchConfiguration - org.springframework.batch.core.configuration.annotation中的类
Base Configuration class providing common structure for enabling and using Spring Batch.
SimpleBatchConfiguration() - 类 的构造器org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
SimpleBinaryBufferedReaderFactory - org.springframework.batch.item.file中的类
A BufferedReaderFactory useful for reading simple binary (or text) files with no line endings, such as those produced by mainframe copy books.
SimpleBinaryBufferedReaderFactory() - 类 的构造器org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
 
SimpleChunkProcessor<I,​O> - org.springframework.batch.core.step.item中的类
Simple implementation of the ChunkProcessor interface that handles basic item writing and processing.
SimpleChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>) - 类 的构造器org.springframework.batch.core.step.item.SimpleChunkProcessor
 
SimpleChunkProcessor(ItemWriter<? super O>) - 类 的构造器org.springframework.batch.core.step.item.SimpleChunkProcessor
 
SimpleChunkProvider<I> - org.springframework.batch.core.step.item中的类
Simple implementation of the ChunkProvider interface that does basic chunk providing from an ItemReader.
SimpleChunkProvider(ItemReader<? extends I>, RepeatOperations) - 类 的构造器org.springframework.batch.core.step.item.SimpleChunkProvider
 
SimpleCompletionPolicy - org.springframework.batch.repeat.policy中的类
Policy for terminating a batch after a fixed number of operations.
SimpleCompletionPolicy() - 类 的构造器org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy(int) - 类 的构造器org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy.SimpleTerminationContext - org.springframework.batch.repeat.policy中的类
 
SimpleFlow - org.springframework.batch.core.job.flow.support中的类
A Flow that branches conditionally depending on the exit status of the last State.
SimpleFlow(String) - 类 的构造器org.springframework.batch.core.job.flow.support.SimpleFlow
Create a flow with the given name.
SimpleFlowFactoryBean - org.springframework.batch.core.configuration.xml中的类
Convenience factory for SimpleFlow instances for use in XML namespace.
SimpleFlowFactoryBean() - 类 的构造器org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
SimpleFlowFactoryBean.DelegateState - org.springframework.batch.core.configuration.xml中的类
A State that proxies a delegate and changes its name but leaves its behavior unchanged.
SimpleJob - org.springframework.batch.core.job中的类
Simple implementation of Job interface providing the ability to run a JobExecution.
SimpleJob() - 类 的构造器org.springframework.batch.core.job.SimpleJob
Default constructor for job with null name
SimpleJob(String) - 类 的构造器org.springframework.batch.core.job.SimpleJob
 
SimpleJobBuilder - org.springframework.batch.core.job.builder中的类
 
SimpleJobBuilder(JobBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.job.builder.SimpleJobBuilder
Create a new builder initialized with any properties in the parent.
SimpleJobExplorer - org.springframework.batch.core.explore.support中的类
Implementation of JobExplorer using the injected DAOs.
SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - 类 的构造器org.springframework.batch.core.explore.support.SimpleJobExplorer
 
SimpleJobLauncher - org.springframework.batch.core.launch.support中的类
Simple implementation of the JobLauncher interface.
SimpleJobLauncher() - 类 的构造器org.springframework.batch.core.launch.support.SimpleJobLauncher
 
SimpleJobOperator - org.springframework.batch.core.launch.support中的类
Simple implementation of the JobOperator interface.
SimpleJobOperator() - 类 的构造器org.springframework.batch.core.launch.support.SimpleJobOperator
 
SimpleJobRepository - org.springframework.batch.core.repository.support中的类
Implementation of JobRepository that stores JobInstances, JobExecutions, and StepExecutions using the injected DAOs.
SimpleJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - 类 的构造器org.springframework.batch.core.repository.support.SimpleJobRepository
 
SimpleJvmExitCodeMapper - org.springframework.batch.core.launch.support中的类
An implementation of ExitCodeMapper that can be configured through a map from batch exit codes (String) to integer results.
SimpleJvmExitCodeMapper() - 类 的构造器org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
SimpleLimitExceptionHandler - org.springframework.batch.repeat.exception中的类
Simple implementation of exception handler which looks for given exception types.
SimpleLimitExceptionHandler() - 类 的构造器org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Default constructor for the SimpleLimitExceptionHandler.
SimpleLimitExceptionHandler(int) - 类 的构造器org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Convenience constructor for the SimpleLimitExceptionHandler to set the limit.
SimpleMailMessageItemWriter - org.springframework.batch.item.mail中的类
A simple ItemWriter that can send mail messages.
SimpleMailMessageItemWriter() - 类 的构造器org.springframework.batch.item.mail.SimpleMailMessageItemWriter
 
SimpleMailMessageItemWriterBuilder - org.springframework.batch.item.mail.builder中的类
Creates a fully qualified SimpleMailMessageItemWriter.
SimpleMailMessageItemWriterBuilder() - 类 的构造器org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
 
SimpleMessageApplicationEvent - org.springframework.batch.sample.jmx中的类
 
SimpleMessageApplicationEvent(Object, String) - 类 的构造器org.springframework.batch.sample.jmx.SimpleMessageApplicationEvent
 
SimpleMethodInvoker - org.springframework.batch.support中的类
Simple implementation of the MethodInvoker interface that invokes a method on an object.
SimpleMethodInvoker(Object, Method) - 类 的构造器org.springframework.batch.support.SimpleMethodInvoker
 
SimpleMethodInvoker(Object, String, Class<?>...) - 类 的构造器org.springframework.batch.support.SimpleMethodInvoker
 
SimpleMetric - org.springframework.batch.core.jsr中的类
Simple implementation of the Metric interface as required by JSR-352.
SimpleMetric(Metric.MetricType, long) - 类 的构造器org.springframework.batch.core.jsr.SimpleMetric
Basic constructor.
SimplePartitioner - org.springframework.batch.core.partition.support中的类
Simplest possible implementation of Partitioner.
SimplePartitioner() - 类 的构造器org.springframework.batch.core.partition.support.SimplePartitioner
 
SimpleRecordSeparatorPolicy - org.springframework.batch.item.file.separator中的类
Simplest possible RecordSeparatorPolicy - treats all lines as record endings.
SimpleRecordSeparatorPolicy() - 类 的构造器org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
 
SimpleResourceSuffixCreator - org.springframework.batch.item.file中的类
Trivial implementation of ResourceSuffixCreator that uses the index itself as suffix, separated by dot.
SimpleResourceSuffixCreator() - 类 的构造器org.springframework.batch.item.file.SimpleResourceSuffixCreator
 
SimpleRetryExceptionHandler - org.springframework.batch.core.step.item中的类
An ExceptionHandler that is aware of the retry context so that it can distinguish between a fatal exception and one that can be retried.
SimpleRetryExceptionHandler(RetryPolicy, ExceptionHandler, Collection<Class<? extends Throwable>>) - 类 的构造器org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Create an exception handler from its mandatory properties.
SimpleStepBuilder<I,​O> - org.springframework.batch.core.step.builder中的类
Step builder for simple item processing (chunk oriented) steps.
SimpleStepBuilder(SimpleStepBuilder<I, O>) - 类 的构造器org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepExecutionSplitter - org.springframework.batch.core.partition.support中的类
Generic implementation of StepExecutionSplitter that delegates to a Partitioner to generate ExecutionContext instances.
SimpleStepExecutionSplitter() - 类 的构造器org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Default constructor for convenience in configuration.
SimpleStepExecutionSplitter(JobRepository, boolean, String, Partitioner) - 类 的构造器org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Construct a SimpleStepExecutionSplitter from its mandatory properties.
SimpleStepExecutionSplitter(JobRepository, Step, Partitioner) - 类 的构造器org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
SimpleStepFactoryBean<T,​S> - org.springframework.batch.core.step.factory中的类
Most common configuration options for simple steps should be found here.
SimpleStepFactoryBean() - 类 的构造器org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Default constructor for SimpleStepFactoryBean.
SimpleStepHandler - org.springframework.batch.core.job中的类
Implementation of StepHandler that manages repository and restart concerns.
SimpleStepHandler() - 类 的构造器org.springframework.batch.core.job.SimpleStepHandler
Convenient default constructor for configuration usage.
SimpleStepHandler(JobRepository) - 类 的构造器org.springframework.batch.core.job.SimpleStepHandler
 
SimpleStepHandler(JobRepository, ExecutionContext) - 类 的构造器org.springframework.batch.core.job.SimpleStepHandler
 
SimpleSystemProcessExitCodeMapper - org.springframework.batch.core.step.tasklet中的类
Simple SystemProcessExitCodeMapper implementation that performs following mapping: 0 -> ExitStatus.FINISHED else -> ExitStatus.FAILED
SimpleSystemProcessExitCodeMapper() - 类 的构造器org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
SimpleTerminationContext(RepeatContext) - 类 的构造器org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
SingleItemPeekableItemReader<T> - org.springframework.batch.item.support中的类
A PeekableItemReader that allows the user to peek one item ahead.
SingleItemPeekableItemReader() - 类 的构造器org.springframework.batch.item.support.SingleItemPeekableItemReader
 
SingleItemPeekableItemReaderBuilder<T> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified SingleItemPeekeableItemReader.
SingleItemPeekableItemReaderBuilder() - 类 的构造器org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
 
size() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
size() - 类 中的方法org.springframework.batch.item.ExecutionContext
Returns number of entries in the context
skip(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly request certain exceptions (and subclasses) to be skipped.
skip(Class<? extends Throwable>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
skip(Exception) - 类 中的方法org.springframework.batch.core.step.item.Chunk
Register an anonymous skip.
SKIP_PROCESS - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
SKIP_READ - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
SKIP_WRITE - org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
SkipException - org.springframework.batch.core.step.skip中的异常错误
Base exception indicating that the skip has failed or caused a failure.
SkipException(String) - 异常错误 的构造器org.springframework.batch.core.step.skip.SkipException
 
SkipException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.SkipException
 
skipLimit(int) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the maximum number of failed items to skip before the step fails.
skipLimit(int) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
SkipLimitExceededException - org.springframework.batch.core.step.skip中的异常错误
Exception indicating that the skip limit for a particular Step has been exceeded.
SkipLimitExceededException(int, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.SkipLimitExceededException
 
SkipListener<T,​S> - org.springframework.batch.core中的接口
Interface for listener to skipped items.
SkipListenerAdapter<T,​S> - org.springframework.batch.core.jsr中的类
 
SkipListenerAdapter(SkipReadListener, SkipProcessListener, SkipWriteListener) - 类 的构造器org.springframework.batch.core.jsr.SkipListenerAdapter
 
SkipListenerFailedException - org.springframework.batch.core.step.skip中的异常错误
Special exception to indicate a failure in a skip listener.
SkipListenerFailedException(String, RuntimeException, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.SkipListenerFailedException
 
SkipListenerSupport<T,​S> - org.springframework.batch.core.listener中的类
Basic no-op implementations of all SkipListener implementations.
SkipListenerSupport() - 类 的构造器org.springframework.batch.core.listener.SkipListenerSupport
 
SkipOverflowException - org.springframework.batch.core.step.item中的异常错误
 
SkipOverflowException(String) - 异常错误 的构造器org.springframework.batch.core.step.item.SkipOverflowException
 
SkippableExceptionDuringProcessSample - org.springframework.batch.sample.skip中的类
 
SkippableExceptionDuringProcessSample(JobBuilderFactory, StepBuilderFactory) - 类 的构造器org.springframework.batch.sample.skip.SkippableExceptionDuringProcessSample
 
SkippableExceptionDuringReadSample - org.springframework.batch.sample.skip中的类
 
SkippableExceptionDuringReadSample(JobBuilderFactory, StepBuilderFactory) - 类 的构造器org.springframework.batch.sample.skip.SkippableExceptionDuringReadSample
 
SkippableExceptionDuringWriteSample - org.springframework.batch.sample.skip中的类
 
SkippableExceptionDuringWriteSample(JobBuilderFactory, StepBuilderFactory) - 类 的构造器org.springframework.batch.sample.skip.SkippableExceptionDuringWriteSample
 
skippedLinesCallback(LineCallbackHandler) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A callback to be called for each line that is skipped.
skippedRecordsCallback(RecordCallbackHandler) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
RecordCallbackHandler implementations can be used to take action on skipped records.
skippedRecordsCallback(RecordCallbackHandler) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
RecordCallbackHandler implementations can be used to take action on skipped records.
skipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit policy for managing skips.
skipPolicy(SkipPolicy) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
SkipPolicy - org.springframework.batch.core.step.skip中的接口
Policy for determining whether or not some processing should be skipped.
SkipPolicyFailedException - org.springframework.batch.core.step.skip中的异常错误
Special exception to indicate a failure in a skip policy.
SkipPolicyFailedException(String, RuntimeException, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.skip.SkipPolicyFailedException
 
SkipWrapper<T> - org.springframework.batch.core.step.item中的类
Wrapper for an item and its exception if it failed processing.
SkipWrapper(Throwable) - 类 的构造器org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(T) - 类 的构造器org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(T, Throwable) - 类 的构造器org.springframework.batch.core.step.item.SkipWrapper
 
SleepingItemProcessor<I> - org.springframework.batch.core.test.timeout中的类
 
SleepingItemProcessor() - 类 的构造器org.springframework.batch.core.test.timeout.SleepingItemProcessor
 
SleepingTasklet - org.springframework.batch.core.test.timeout中的类
 
SleepingTasklet() - 类 的构造器org.springframework.batch.core.test.timeout.SleepingTasklet
 
sortKeys(Map<String, Order>) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The keys to sort by.
sorts(Map<String, Sort.Direction>) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Map of property names/Sort.Direction values to sort the input by.
sorts(Map<String, Sort.Direction>) - 类 中的方法org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Provides ordering of the results so that order is maintained between paged queries.
SpELItemKeyMapper<K,​V> - org.springframework.batch.item中的类
An implementation of Converter that uses SpEL to map a Value to a key
SpELItemKeyMapper(String) - 类 的构造器org.springframework.batch.item.SpELItemKeyMapper
 
SpELMappingGemfireItemWriter<K,​V> - org.springframework.batch.item.data中的类
A convenient GemfireItemWriter implementation that uses a SpELItemKeyMapper
split(StepExecution, int) - 类 中的方法org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
Returns the same number of StepExecutions as the gridSize specifies.
split(StepExecution, int) - 接口 中的方法org.springframework.batch.core.partition.StepExecutionSplitter
Partition the provided StepExecution into a set of parallel executable instances with the same parent JobExecution.
split(StepExecution, int) - 类 中的方法org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
split(TaskExecutor) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
 
split(TaskExecutor) - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
 
SPLIT_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
SplitBuilder(FlowBuilder<Q>, TaskExecutor) - 类 的构造器org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
 
SplitParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <split/> elements inside a job.
SplitParser(String) - 类 的构造器org.springframework.batch.core.configuration.xml.SplitParser
Construct a InlineFlowParser using the provided job repository ref.
SplitState - org.springframework.batch.core.job.flow.support.state中的类
A State implementation that splits a Flow into multiple parallel subflows.
SplitState(Collection<Flow>, String) - 类 的构造器org.springframework.batch.core.job.flow.support.state.SplitState
 
splitter(StepExecutionSplitter) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit StepExecutionSplitter instead of having one build from the PartitionStepBuilder.partitioner(String, Partitioner).
splitter(StepExecutionSplitter) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
SpringBatchTest - org.springframework.batch.test.context中的注释类型
Annotation that can be specified on a test class that runs Spring Batch based tests.
SpringValidator<T> - org.springframework.batch.item.validator中的类
Adapts the Validator interface to Validator.
SpringValidator() - 类 的构造器org.springframework.batch.item.validator.SpringValidator
 
sql(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Set the SQL statement to be used for each item's updates.
sql(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The query to be executed for this reader
SQLITE - org.springframework.batch.support.DatabaseType
 
SqlitePagingQueryProvider - org.springframework.batch.item.database.support中的类
SQLite implementation of a PagingQueryProvider using database specific features.
SqlitePagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
SqlPagingQueryProviderFactoryBean - org.springframework.batch.item.database.support中的类
Factory bean for PagingQueryProvider interface.
SqlPagingQueryProviderFactoryBean() - 类 的构造器org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
SqlPagingQueryUtils - org.springframework.batch.item.database.support中的类
Utility class that generates the actual SQL statements used by query providers.
SqlPagingQueryUtils() - 类 的构造器org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
SQLSERVER - org.springframework.batch.support.DatabaseType
 
SqlServerPagingQueryProvider - org.springframework.batch.item.database.support中的类
SQL Server implementation of a PagingQueryProvider using database specific features.
SqlServerPagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
SqlWindowingPagingQueryProvider - org.springframework.batch.item.database.support中的类
Generic Paging Query Provider using standard SQL:2003 windowing functions.
SqlWindowingPagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
StagingItemListener - org.springframework.batch.sample.common中的类
Thread-safe database ItemReader implementing the process indicator pattern.
StagingItemListener() - 类 的构造器org.springframework.batch.sample.common.StagingItemListener
 
StagingItemProcessor<T> - org.springframework.batch.sample.common中的类
Marks the input row as 'processed'.
StagingItemProcessor() - 类 的构造器org.springframework.batch.sample.common.StagingItemProcessor
 
StagingItemReader<T> - org.springframework.batch.sample.common中的类
Thread-safe database ItemReader implementing the process indicator pattern.
StagingItemReader() - 类 的构造器org.springframework.batch.sample.common.StagingItemReader
 
StagingItemWriter<T> - org.springframework.batch.sample.common中的类
Database ItemWriter implementing the process indicator pattern.
StagingItemWriter() - 类 的构造器org.springframework.batch.sample.common.StagingItemWriter
 
StandaloneStepParser - org.springframework.batch.core.configuration.xml中的类
Internal parser for the <step/> elements for a job.
StandaloneStepParser() - 类 的构造器org.springframework.batch.core.configuration.xml.StandaloneStepParser
 
start() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Take all the contexts from the factories provided and pass them to the JobLoader.
start() - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
start(String, String) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Start a new instance of a job with the parameters specified.
start(String, String) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
start(String, Properties) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
Creates a child ApplicationContext for the job being requested based upon the /META-INF/batch.xml (if exists) and the /META-INF/batch-jobs/<jobName>.xml configuration and launches the job.
start(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a subflow use this as the first state.
start(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this flow, but expect to transition from there to other flows or steps.
start(Flow) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a flow.
start(FlowExecutor) - 接口 中的方法org.springframework.batch.core.job.flow.Flow
 
start(FlowExecutor) - 类 中的方法org.springframework.batch.core.job.flow.support.SimpleFlow
 
start(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a decision use this as the first state.
start(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
Start with this decider.
start(Step) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
Start a flow.
start(Step) - 类 中的方法org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this step, but expect to transition from there to other flows or steps.
start(Step) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
start(Step) - 类 中的方法org.springframework.batch.core.job.builder.SimpleJobBuilder
Start the job with this step.
start(RepeatContext) - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
start(RepeatContext) - 类 中的方法org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
start(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.CompletionPolicy
Create a new context for the execution of a batch.
start(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CompletionPolicySupport
Build a new RepeatContextSupport and return it.
start(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Create a new composite context from all the available policies.
start(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
start(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Reset the counter.
start(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Start the clock on the timeout.
startCloseSuppression(Connection) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
startDocument(XMLEventWriter) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Writes simple XML header containing: xml declaration - defines encoding and XML version opening tag of the root element and its attributes If this is not sufficient for you, simply override this method.
STARTED - org.springframework.batch.core.BatchStatus
 
STARTING - org.springframework.batch.core.BatchStatus
 
startLimit(int) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
startLimit(int) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
startLimit(int) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
startLimit(int) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
StartLimitExceededException - org.springframework.batch.core中的异常错误
Indicates the step's start limit has been exceeded.
StartLimitExceededException(String) - 异常错误 的构造器org.springframework.batch.core.StartLimitExceededException
 
startNextInstance(String) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Launch the next in a sequence of JobInstance determined by the JobParametersIncrementer attached to the specified job.
startNextInstance(String) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
startStatement(String) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The start segment of the cypher query.
state - 类 中的变量org.springframework.batch.item.support.AbstractFileItemWriter
 
State - org.springframework.batch.core.job.flow中的接口
 
STATE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
STATE_TRANSITION_COMPARATOR - 类 中的静态变量org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
StateTransition - org.springframework.batch.core.job.flow.support中的类
Value object representing a potential transition from one State to another.
StaxEventItemReader<T> - org.springframework.batch.item.xml中的类
Item reader for reading XML input based on StAX.
StaxEventItemReader() - 类 的构造器org.springframework.batch.item.xml.StaxEventItemReader
 
StaxEventItemReaderBuilder<T> - org.springframework.batch.item.xml.builder中的类
A fluent builder for the StaxEventItemReader
StaxEventItemReaderBuilder() - 类 的构造器org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
 
StaxEventItemWriter<T> - org.springframework.batch.item.xml中的类
An implementation of ItemWriter which uses StAX and Marshaller for serializing object to XML.
StaxEventItemWriter() - 类 的构造器org.springframework.batch.item.xml.StaxEventItemWriter
 
StaxEventItemWriterBuilder<T> - org.springframework.batch.item.xml.builder中的类
A builder for the StaxEventItemWriter.
StaxEventItemWriterBuilder() - 类 的构造器org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
 
StaxUtils - org.springframework.batch.item.xml中的类
StAX utility methods.
StaxUtils() - 类 的构造器org.springframework.batch.item.xml.StaxUtils
 
StaxWriterCallback - org.springframework.batch.item.xml中的接口
Callback interface for writing to an XML file - useful e.g. for handling headers and footers.
step() - 类 中的方法org.springframework.batch.sample.config.RetrySampleConfiguration
 
step() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringProcessSample
 
step() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringReadSample
 
step() - 类 中的方法org.springframework.batch.sample.skip.SkippableExceptionDuringWriteSample
 
step() - 类 中的方法org.springframework.batch.sample.validation.ValidationSampleConfiguration
 
step(Step) - 类 中的方法org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
step(Step) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an actual step instance to execute in parallel.
step(Step) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
Step - org.springframework.batch.core中的接口
Batch domain interface representing the configuration of a step.
STEP - org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
 
STEP_ARTIFACT - org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
 
STEP_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
STEP_EXECUTION - 类 中的静态变量org.springframework.batch.integration.async.StepExecutionInterceptor
The name of the header
STEP_TYPE_KEY - 接口 中的静态变量org.springframework.batch.core.Step
 
StepBuilder - org.springframework.batch.core.step.builder中的类
Convenient entry point for building all kinds of steps.
StepBuilder(String) - 类 的构造器org.springframework.batch.core.step.builder.StepBuilder
Initialize a step builder for a step with the given name.
StepBuilderException - org.springframework.batch.core.step.builder中的异常错误
Utility exception thrown by builders when they encounter unexpected checked exceptions.
StepBuilderException(Exception) - 异常错误 的构造器org.springframework.batch.core.step.builder.StepBuilderException
 
StepBuilderFactory - org.springframework.batch.core.configuration.annotation中的类
Convenient factory for a StepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
StepBuilderFactory(JobRepository, PlatformTransactionManager) - 类 的构造器org.springframework.batch.core.configuration.annotation.StepBuilderFactory
 
StepBuilderHelper<B extends StepBuilderHelper<B>> - org.springframework.batch.core.step.builder中的类
A base class and utility for other step builders providing access to common properties like job repository and transaction manager.
StepBuilderHelper(String) - 类 的构造器org.springframework.batch.core.step.builder.StepBuilderHelper
 
StepBuilderHelper(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.StepBuilderHelper
Create a new builder initialized with any properties in the parent.
StepBuilderHelper.CommonStepProperties - org.springframework.batch.core.step.builder中的类
 
stepBuilders() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
StepContext - org.springframework.batch.core.scope.context中的类
A context object that can be used to interrogate the current StepExecution and some of its associated properties using expressions based on bean paths.
StepContext(StepExecution) - 类 的构造器org.springframework.batch.core.scope.context.StepContext
Create a new instance of StepContext for this StepExecution.
StepContext(StepExecution, BatchPropertyContext) - 类 的构造器org.springframework.batch.core.scope.context.StepContext
 
StepContextRepeatCallback - org.springframework.batch.core.scope.context中的类
Convenient base class for clients who need to do something in a repeat callback inside a Step.
StepContextRepeatCallback(StepExecution) - 类 的构造器org.springframework.batch.core.scope.context.StepContextRepeatCallback
 
StepContribution - org.springframework.batch.core中的类
Represents a contribution to a StepExecution, buffering changes until they can be applied at a chunk boundary.
StepContribution(StepExecution) - 类 的构造器org.springframework.batch.core.StepContribution
 
StepContributionSource - org.springframework.batch.integration.chunk中的接口
A source of StepContribution instances that can be aggregated and used to update an ongoing StepExecution.
StepExecution - org.springframework.batch.core中的类
Batch domain object representation the execution of a step.
StepExecution(String, JobExecution) - 类 的构造器org.springframework.batch.core.StepExecution
Constructor that substitutes in null for the execution id
StepExecution(String, JobExecution, Long) - 类 的构造器org.springframework.batch.core.StepExecution
Constructor with mandatory properties.
StepExecutionAggregator - org.springframework.batch.core.partition.support中的接口
Strategy for a aggregating step executions, usually when they are the result of partitioned or remote execution.
StepExecutionApplicationEventAdvice - org.springframework.batch.sample.jmx中的类
Wraps calls for methods taking StepExecution as an argument and publishes notifications in the form of ApplicationEvent.
StepExecutionApplicationEventAdvice() - 类 的构造器org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
StepExecutionDao - org.springframework.batch.core.repository.dao中的接口
 
StepExecutionInterceptor - org.springframework.batch.integration.async中的类
A ChannelInterceptor that adds the current StepExecution (if there is one) as a header to the message.
StepExecutionInterceptor() - 类 的构造器org.springframework.batch.integration.async.StepExecutionInterceptor
 
StepExecutionListener - org.springframework.batch.core中的接口
Listener interface for the lifecycle of a Step.
stepExecutionListenerMetaData() - 枚举 中的静态方法org.springframework.batch.core.listener.StepListenerMetaData
 
StepExecutionListenerSupport - org.springframework.batch.core.listener中的类
 
StepExecutionListenerSupport() - 类 的构造器org.springframework.batch.core.listener.StepExecutionListenerSupport
 
StepExecutionRequest - org.springframework.batch.integration.partition中的类
Class encapsulating information required to request a step execution in a remote partitioning setup.
StepExecutionRequest(String, Long, Long) - 类 的构造器org.springframework.batch.integration.partition.StepExecutionRequest
Create a new StepExecutionRequest instance.
StepExecutionRequestHandler - org.springframework.batch.integration.partition中的类
A MessageEndpoint that can handle a StepExecutionRequest and return a StepExecution as the result.
StepExecutionRequestHandler() - 类 的构造器org.springframework.batch.integration.partition.StepExecutionRequestHandler
 
StepExecutionSimpleCompletionPolicy - org.springframework.batch.core.resource中的类
A CompletionPolicy that picks up a commit interval from JobParameters by listening to the start of a step.
StepExecutionSimpleCompletionPolicy() - 类 的构造器org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
StepExecutionSplitter - org.springframework.batch.core.partition中的接口
Strategy interface for generating input contexts for a partitioned step execution independent from the fabric they are going to run on.
StepFactoryBean<I,​O> - org.springframework.batch.core.jsr.configuration.xml中的类
This FactoryBean is used by the JSR-352 namespace parser to create Step objects.
StepFactoryBean() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
StepHandler - org.springframework.batch.core.job中的接口
Strategy interface for handling a Step on behalf of a Job.
StepHolder - org.springframework.batch.core.step中的接口
Interface for holders of a Step as a convenience for callers who need access to the underlying instance.
StepInterruptionPolicy - org.springframework.batch.core.step中的接口
Strategy interface for an interruption policy.
StepListener - org.springframework.batch.core中的接口
Marker interface that acts as a parent to all step domain listeners, such as: StepExecutionListener, ChunkListener, ItemReadListener and ItemWriteListener
StepListenerAdapter - org.springframework.batch.core.jsr中的类
Wrapper class to adapt the StepListener to a StepExecutionListener.
StepListenerAdapter(StepListener) - 类 的构造器org.springframework.batch.core.jsr.StepListenerAdapter
 
StepListenerFactoryBean - org.springframework.batch.core.listener中的类
This AbstractListenerFactoryBean implementation is used to create a StepListener.
StepListenerFactoryBean() - 类 的构造器org.springframework.batch.core.listener.StepListenerFactoryBean
 
StepListenerFailedException - org.springframework.batch.core.listener中的异常错误
Exception to indicate a problem in a step listener.
StepListenerFailedException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.listener.StepListenerFailedException
 
StepListenerMetaData - org.springframework.batch.core.listener中的枚举
Enumeration for StepListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
StepListenerParser - org.springframework.batch.core.configuration.xml中的类
Parser for a step listener element.
StepListenerParser() - 类 的构造器org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerParser(ListenerMetaData[]) - 类 的构造器org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerSupport<T,​S> - org.springframework.batch.core.listener中的类
Basic no-op implementations of all StepListener interfaces.
StepListenerSupport() - 类 的构造器org.springframework.batch.core.listener.StepListenerSupport
 
stepLocator - 类 中的变量org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepLocator(StepLocator) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the step locator used to locate the worker step to execute.
StepLocator - org.springframework.batch.core.step中的接口
Interface for locating a Step instance by name.
StepLocatorStepFactoryBean - org.springframework.batch.core.step中的类
Convenience factory for Step instances given a StepLocator.
StepLocatorStepFactoryBean() - 类 的构造器org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepName - 类 中的变量org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepOperations(RepeatOperations) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the repeat template used for iterating the tasklet execution.
stepOperations(RepeatOperations) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
StepParser - org.springframework.batch.core.jsr.configuration.xml中的类
Parser for the <step /> element defined by JSR-352.
StepParser() - 类 的构造器org.springframework.batch.core.jsr.configuration.xml.StepParser
 
StepParserStepFactoryBean<I,​O> - org.springframework.batch.core.configuration.xml中的类
This FactoryBean is used by the batch namespace parser to create Step objects.
StepParserStepFactoryBean() - 类 的构造器org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
StepRegistry - org.springframework.batch.core.configuration中的接口
Registry keeping track of all the Step defined in a Job.
StepRunner - org.springframework.batch.test中的类
Utility class for executing steps outside of a Job.
StepRunner(JobLauncher, JobRepository) - 类 的构造器org.springframework.batch.test.StepRunner
 
StepScope - org.springframework.batch.core.scope中的类
Scope for step context.
StepScope - org.springframework.batch.core.configuration.annotation中的注释类型
Convenient annotation for step scoped beans that defaults the proxy mode, so that it doesn't have to be specified explicitly on every bean definition.
StepScope() - 类 的构造器org.springframework.batch.core.scope.StepScope
 
StepScopeManager - org.springframework.batch.core.scope.context中的类
Convenient aspect to wrap a single threaded step execution, where the implementation of the Step is not step scope aware (i.e. not the ones provided by the framework).
StepScopeManager() - 类 的构造器org.springframework.batch.core.scope.context.StepScopeManager
 
StepScopeTestExecutionListener - org.springframework.batch.test中的类
A TestExecutionListener that sets up step-scope context for dependency injection into unit tests.
StepScopeTestExecutionListener() - 类 的构造器org.springframework.batch.test.StepScopeTestExecutionListener
 
StepScopeTestUtils - org.springframework.batch.test中的类
Utility class for creating and manipulating StepScope in unit tests.
StepScopeTestUtils() - 类 的构造器org.springframework.batch.test.StepScopeTestUtils
 
StepState - org.springframework.batch.core.job.flow.support.state中的类
State implementation that delegates to a FlowExecutor to execute the specified Step.
StepState(String, Step) - 类 的构造器org.springframework.batch.core.job.flow.support.state.StepState
 
StepState(Step) - 类 的构造器org.springframework.batch.core.job.flow.support.state.StepState
 
StepSynchronizationManager - org.springframework.batch.core.scope.context中的类
Central convenience class for framework use in managing the step scope context.
StepSynchronizationManager() - 类 的构造器org.springframework.batch.core.scope.context.StepSynchronizationManager
 
stop() - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Delegates to JobLoader.clear().
stop() - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
stop() - 类 中的方法org.springframework.batch.core.JobExecution
Signal the JobExecution to stop.
stop() - 类 中的方法org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
 
stop() - 类 中的静态方法org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
If embedded in a JVM, call this method to terminate the main method.
stop() - 接口 中的方法org.springframework.batch.core.step.tasklet.StoppableTasklet
Used to signal that the job this Tasklet is executing within has been requested to stop.
stop() - 类 中的方法org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Will interrupt the thread executing the system command only if SystemCommandTasklet.setInterruptOnCancel(boolean) has been set to true.
stop(long) - 类 中的方法org.springframework.batch.core.jsr.launch.JsrJobOperator
Stops the running job execution if it is currently running.
stop(long) - 接口 中的方法org.springframework.batch.core.launch.JobOperator
Send a stop signal to the JobExecution with the supplied id.
stop(long) - 类 中的方法org.springframework.batch.core.launch.support.SimpleJobOperator
 
stop(Runnable) - 类 中的方法org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
stop(String) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
 
stop(String, State) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder
 
STOP_ELE - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
stopAndRestart(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a flow to start with if the flow is restarted.
stopAndRestart(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a decider to start with if the flow is restarted.
stopAndRestart(Step) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a step to start with if the flow is restarted.
stopCloseSuppression(Connection) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
StoppableTasklet - org.springframework.batch.core.step.tasklet中的接口
An extension to the Tasklet interface to allow users to add logic for stopping a tasklet.
STOPPED - org.springframework.batch.core.BatchStatus
 
STOPPED - 类 中的静态变量org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing with interrupted status.
STOPPED - 类 中的静态变量org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
STOPPING - org.springframework.batch.core.BatchStatus
 
StoredProcedureItemReader<T> - org.springframework.batch.item.database中的类
Item reader implementation that executes a stored procedure and then reads the returned cursor and continually retrieves the next row in the ResultSet.
StoredProcedureItemReader() - 类 的构造器org.springframework.batch.item.database.StoredProcedureItemReader
 
StoredProcedureItemReaderBuilder<T> - org.springframework.batch.item.database.builder中的类
A fluent builder API for the configuration of a StoredProcedureItemReader.
StoredProcedureItemReaderBuilder() - 类 的构造器org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
 
stream(ItemStream) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a stream for callbacks that manage restart data.
stream(ItemStream) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
stream(ItemStream) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
strict(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
Boolean indicating if the number of tokens in a line must match the number of fields (ranges) configured.
strict(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure if the reader should be in strict mode (require the input Resource to exist).
strict(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Setting this value to true indicates that it is an error if the input does not exist and an exception will be thrown.
strict(boolean) - 类 中的方法org.springframework.batch.item.ldif.builder.LdifReaderBuilder
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
strict(boolean) - 类 中的方法org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
strict(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Setting this value to true indicates that it is an error if the input does not exist and an exception will be thrown.
STRING - org.springframework.batch.core.JobParameter.ParameterType
 
STRING_TYPE - 类 中的静态变量org.springframework.batch.core.converter.DefaultJobParametersConverter
 
stringToProperties(String) - 类 中的静态方法org.springframework.batch.support.PropertiesConverter
Parse a String to a Properties object.
SuffixRecordSeparatorPolicy - org.springframework.batch.item.file.separator中的类
A RecordSeparatorPolicy that looks for an exact match for a String at the end of a line (e.g. a semicolon).
SuffixRecordSeparatorPolicy() - 类 的构造器org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
 
SummaryFooterCallback - org.springframework.batch.sample.support中的类
Writes summary info in the footer of a file.
SummaryFooterCallback() - 类 的构造器org.springframework.batch.sample.support.SummaryFooterCallback
 
supports(Class<?>) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
supports(Class<?>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.validator.TradeValidator
 
switchOriginAndDestination(StateTransition, State, String) - 类 中的静态方法org.springframework.batch.core.job.flow.support.StateTransition
Convenience method to switch the origin and destination of a transition, creating a new instance.
SYBASE - org.springframework.batch.support.DatabaseType
 
SybasePagingQueryProvider - org.springframework.batch.item.database.support中的类
Sybase implementation of a PagingQueryProvider using database specific features.
SybasePagingQueryProvider() - 类 的构造器org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
SynchronizationManagerSupport<E,​C> - org.springframework.batch.core.scope.context中的类
Central convenience class for framework use in managing the scope context.
SynchronizationManagerSupport() - 类 的构造器org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
SynchronizedAttributeAccessor - org.springframework.batch.repeat.context中的类
An AttributeAccessor that synchronizes on a mutex (not this) before modifying or accessing the underlying attributes.
SynchronizedAttributeAccessor() - 类 的构造器org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
SynchronizedItemStreamReader<T> - org.springframework.batch.item.support中的类
This is a simple ItemStreamReader decorator with a synchronized ItemReader.read() method - which makes a non-thread-safe ItemReader thread-safe.
SynchronizedItemStreamReader() - 类 的构造器org.springframework.batch.item.support.SynchronizedItemStreamReader
 
SynchronizedItemStreamReaderBuilder<T> - org.springframework.batch.item.support.builder中的类
Creates a fully qualified SynchronizedItemStreamReader.
SynchronizedItemStreamReaderBuilder() - 类 的构造器org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
 
synchronizeStatus(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
synchronizeStatus(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
Because it may be possible that the status of a JobExecution is updated while running, the following method will synchronize only the status and version fields.
synchronizeStatus(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
SystemCommandException - org.springframework.batch.core.step.tasklet中的异常错误
Exception indicating failed execution of system command.
SystemCommandException(String) - 异常错误 的构造器org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandTasklet - org.springframework.batch.core.step.tasklet中的类
Tasklet that executes a system command.
SystemCommandTasklet() - 类 的构造器org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
SystemExiter - org.springframework.batch.core.launch.support中的接口
Interface for exiting the JVM.
SystemProcessExitCodeMapper - org.springframework.batch.core.step.tasklet中的接口
Maps the exit code of a system process to ExitStatus value returned by a system command.
SystemPropertyInitializer - org.springframework.batch.support中的类
Helper class that sets up a System property with a default value.
SystemPropertyInitializer() - 类 的构造器org.springframework.batch.support.SystemPropertyInitializer
 

T

tablePrefix - 类 中的变量org.springframework.batch.core.jsr.JsrJobParametersConverter
 
take() - 类 中的方法org.springframework.batch.repeat.support.ResultHolderResultQueue
Get the next result as soon as it becomes available.
take() - 类 中的方法org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
targetType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
The type of object to be returned for each AbstractItemCountingItemStreamItemReader.read() call.
targetType(Class<? extends T>) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The class that will represent the "item" to be returned from the reader.
targetType(Class<T>) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The object type to be returned from each call to AbstractItemCountingItemStreamItemReader.read()
taskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Provide a task executor to use when executing the tasklet.
taskExecutor(TaskExecutor) - 类 中的方法org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide a task executor to use when constructing a PartitionHandler from the PartitionStepBuilder.step(Step).
TaskExecutorPartitionHandler - org.springframework.batch.core.partition.support中的类
A PartitionHandler that uses a TaskExecutor to execute the partitioned Step locally in multiple threads.
TaskExecutorPartitionHandler() - 类 的构造器org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
TaskExecutorRepeatTemplate - org.springframework.batch.repeat.support中的类
Provides RepeatOperations support including interceptors that can be used to modify or monitor the behaviour at run time.
This implementation is sufficient to be used to configure transactional behaviour for each item by making the RepeatCallback transactional, or for the whole batch by making the execute method transactional (but only then if the task executor is synchronous).
This class is thread-safe if its collaborators are thread-safe (interceptors, terminationPolicy, callback).
TaskExecutorRepeatTemplate() - 类 的构造器org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
tasklet(String) - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
tasklet(String) - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.WorkerConfiguration
 
tasklet(Tasklet) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilder
Build a step with a custom tasklet, not necessarily item processing.
tasklet(Tasklet) - 类 中的方法org.springframework.batch.core.step.builder.TaskletStepBuilder
 
tasklet(Tasklet) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
Tasklet - org.springframework.batch.core.step.tasklet中的接口
Strategy for processing in a step.
TASKLET_TYPE_KEY - 类 中的静态变量org.springframework.batch.core.step.tasklet.TaskletStep
 
taskletListenerMetaData() - 枚举 中的静态方法org.springframework.batch.core.listener.StepListenerMetaData
 
TaskletParser - org.springframework.batch.core.configuration.xml中的类
Parse a tasklet element for a step.
TaskletParser() - 类 的构造器org.springframework.batch.core.configuration.xml.TaskletParser
 
TaskletStep - org.springframework.batch.core.step.tasklet中的类
Simple implementation of executing the step as a call to a Tasklet, possibly repeated, and each call surrounded by a transaction.
TaskletStep() - 类 的构造器org.springframework.batch.core.step.tasklet.TaskletStep
Default constructor.
TaskletStep(String) - 类 的构造器org.springframework.batch.core.step.tasklet.TaskletStep
 
TaskletStepBuilder - org.springframework.batch.core.step.builder中的类
Builder for tasklet step based on a custom tasklet (not item oriented).
TaskletStepBuilder(StepBuilderHelper<?>) - 类 的构造器org.springframework.batch.core.step.builder.TaskletStepBuilder
Create a new builder initialized with any properties in the parent.
template(GemfireTemplate) - 类 中的方法org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Establishes the GemfireTemplate the writer should use.
template(MongoOperations) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Used to perform operations against the MongoDB instance.
template(MongoOperations) - 类 中的方法org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Set the MongoOperations to be used to save items to be written.
testing - 类 中的静态变量org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
TestMailErrorHandler - org.springframework.batch.sample.domain.mail.internal中的类
This handler prints out failed messages with their exceptions.
TestMailErrorHandler() - 类 的构造器org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
TestMailSender - org.springframework.batch.sample.domain.mail.internal中的类
 
TestMailSender() - 类 的构造器org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
ThreadLocalClassloaderBeanPostProcessor - org.springframework.batch.core.jsr.configuration.support中的类
After the BeanFactory is created, this post processor will evaluate to see if any of the beans referenced from a job definition (as defined by JSR-352) point to class names instead of bean names.
ThreadLocalClassloaderBeanPostProcessor() - 类 的构造器org.springframework.batch.core.jsr.configuration.support.ThreadLocalClassloaderBeanPostProcessor
 
ThreadStepInterruptionPolicy - org.springframework.batch.core.step中的类
Policy that checks the current thread to see if it has been interrupted.
ThreadStepInterruptionPolicy() - 类 的构造器org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
throttleLimit(int) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
In the case of an asynchronous AbstractTaskletStepBuilder.taskExecutor(TaskExecutor) the number of concurrent tasklet executions can be throttled (beyond any throttling provided by a thread pool).
throttleLimit(long) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Public setter for the throttle limit.
ThrottleLimitResultQueue<T> - org.springframework.batch.repeat.support中的类
An implementation of the ResultQueue that throttles the number of expected results, limiting it to a maximum at any given time.
ThrottleLimitResultQueue(int) - 类 的构造器org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
timeout(long) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
When using job repository polling, the time limit to wait.
TimeoutBatchContext(RepeatContext) - 类 的构造器org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
TimeoutTerminationPolicy - org.springframework.batch.repeat.policy中的类
Termination policy that times out after a fixed period.
TimeoutTerminationPolicy() - 类 的构造器org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default constructor.
TimeoutTerminationPolicy(long) - 类 的构造器org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Construct a TimeoutTerminationPolicy with the specified timeout value (in milliseconds).
TimeoutTerminationPolicy.TimeoutBatchContext - org.springframework.batch.repeat.policy中的类
 
to(Flow) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a complete flow.
to(JobExecutionDecider) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a decision.
to(Step) - 类 中的方法org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next step.
TO_ATTR - 类 中的静态变量org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
toJobParameters() - 类 中的方法org.springframework.batch.core.JobParametersBuilder
Conversion method that takes the current state of this builder and returns it as a JobParameters object.
tokenize(String) - 类 中的方法org.springframework.batch.item.file.transform.AbstractLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - 接口 中的方法org.springframework.batch.item.file.transform.LineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - 类 中的方法org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
tokenize(String) - 类 中的方法org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
TopLevelFlowParser - org.springframework.batch.core.configuration.xml中的类
 
TopLevelFlowParser() - 类 的构造器org.springframework.batch.core.configuration.xml.TopLevelFlowParser
 
TopLevelJobListenerParser - org.springframework.batch.core.configuration.xml中的类
Parse <job-listener/> elements in the batch namespace.
TopLevelJobListenerParser() - 类 的构造器org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
TopLevelStepListenerParser - org.springframework.batch.core.configuration.xml中的类
Parse <step-listener/> elements in the batch namespace.
TopLevelStepListenerParser() - 类 的构造器org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
TopLevelStepParser - org.springframework.batch.core.configuration.xml中的类
Parser for the <step/> top level element in the Batch namespace.
TopLevelStepParser() - 类 的构造器org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
toProperties() - 类 中的方法org.springframework.batch.core.JobParameters
 
toString() - 类 中的方法org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
toString() - 类 中的方法org.springframework.batch.core.configuration.support.GroupAwareJob
 
toString() - 类 中的方法org.springframework.batch.core.Entity
 
toString() - 类 中的方法org.springframework.batch.core.ExitStatus
 
toString() - 类 中的方法org.springframework.batch.core.job.AbstractJob
 
toString() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecution
 
toString() - 类 中的方法org.springframework.batch.core.job.flow.FlowExecutionStatus
 
toString() - 类 中的方法org.springframework.batch.core.job.flow.support.state.AbstractState
 
toString() - 类 中的方法org.springframework.batch.core.job.flow.support.state.EndState
 
toString() - 类 中的方法org.springframework.batch.core.job.flow.support.StateTransition
 
toString() - 类 中的方法org.springframework.batch.core.JobExecution
 
toString() - 类 中的方法org.springframework.batch.core.JobInstance
 
toString() - 类 中的方法org.springframework.batch.core.JobParameter
 
toString() - 类 中的方法org.springframework.batch.core.JobParameters
 
toString() - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Delegates to the wrapped CompletionPolicy if set, otherwise returns the value of StepExecutionSimpleCompletionPolicy.setKeyName(String).
toString() - 类 中的方法org.springframework.batch.core.scope.context.ChunkContext
 
toString() - 类 中的方法org.springframework.batch.core.scope.context.JobContext
 
toString() - 类 中的方法org.springframework.batch.core.scope.context.StepContext
 
toString() - 类 中的方法org.springframework.batch.core.step.AbstractStep
 
toString() - 类 中的方法org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
toString() - 类 中的方法org.springframework.batch.core.step.item.Chunk
 
toString() - 类 中的方法org.springframework.batch.core.step.item.SkipWrapper
 
toString() - 类 中的方法org.springframework.batch.core.StepContribution
 
toString() - 类 中的方法org.springframework.batch.core.StepExecution
 
toString() - 类 中的方法org.springframework.batch.core.test.football.Game
 
toString() - 类 中的方法org.springframework.batch.core.test.football.Player
 
toString() - 类 中的方法org.springframework.batch.core.test.football.PlayerSummary
 
toString() - 类 中的方法org.springframework.batch.integration.chunk.ChunkRequest
 
toString() - 类 中的方法org.springframework.batch.integration.chunk.ChunkResponse
 
toString() - 类 中的方法org.springframework.batch.integration.launch.JobLaunchRequest
 
toString() - 类 中的方法org.springframework.batch.integration.partition.StepExecutionRequest
 
toString() - 类 中的方法org.springframework.batch.item.ExecutionContext
 
toString() - 类 中的方法org.springframework.batch.item.file.transform.DefaultFieldSet
 
toString() - 类 中的方法org.springframework.batch.item.file.transform.Range
 
toString() - 类 中的方法org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
toString() - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
toString() - 类 中的方法org.springframework.batch.sample.domain.football.Game
 
toString() - 类 中的方法org.springframework.batch.sample.domain.football.Player
 
toString() - 类 中的方法org.springframework.batch.sample.domain.football.PlayerSummary
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.Address
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.BillingInfo
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.Customer
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Customer
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.internal.xml.Order
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.LineItem
 
toString() - 类 中的方法org.springframework.batch.sample.domain.order.Order
 
toString() - 类 中的方法org.springframework.batch.sample.domain.person.Child
 
toString() - 类 中的方法org.springframework.batch.sample.domain.person.Person
 
toString() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerCredit
 
toString() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerDebit
 
toString() - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdate
 
toString() - 类 中的方法org.springframework.batch.sample.domain.trade.Trade
 
toString() - 类 中的方法org.springframework.batch.sample.jmx.SimpleMessageApplicationEvent
 
toString() - 类 中的方法org.springframework.batch.sample.validation.domain.Person
 
TOTAL_AMOUNT_KEY - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
TOTAL_PRICE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
Trade - org.springframework.batch.sample.domain.trade中的类
 
Trade() - 类 的构造器org.springframework.batch.sample.domain.trade.Trade
 
Trade(long) - 类 的构造器org.springframework.batch.sample.domain.trade.Trade
 
Trade(String, long, BigDecimal, String) - 类 的构造器org.springframework.batch.sample.domain.trade.Trade
 
TradeDao - org.springframework.batch.sample.domain.trade中的接口
Interface for writing a Trade object to an arbitrary output.
TradeFieldSetMapper - org.springframework.batch.sample.domain.trade.internal中的类
 
TradeFieldSetMapper() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
TradeProcessor - org.springframework.batch.sample.domain.trade.internal中的类
Processes the Trade - throwing validation errors if necessary.
TradeProcessor() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.TradeProcessor
 
TradeRowMapper - org.springframework.batch.sample.domain.trade.internal中的类
 
TradeRowMapper() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
TradeValidator - org.springframework.batch.sample.domain.trade.internal.validator中的类
 
TradeValidator() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.validator.TradeValidator
 
TradeWriter - org.springframework.batch.sample.domain.trade.internal中的类
Delegates the actual writing to custom DAO delegate.
TradeWriter() - 类 的构造器org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
transacted(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Indicates if a transaction should be created around the read (true by default).
transactional(boolean) - 类 中的方法org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true, the flushing of the buffer is delayed while a transaction is active.
transactional(boolean) - 类 中的方法org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true, the flushing of the buffer is delayed while a transaction is active.
transactional(boolean) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The resulting writer is participating in a transaction and writes should be delayed as late as possible.
transactionAttribute(TransactionAttribute) - 类 中的方法org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the transaction attributes for the tasklet execution.
transactionAttribute(TransactionAttribute) - 类 中的方法org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
transactionAttribute(TransactionAttribute) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
TransactionAwareBufferedWriter - org.springframework.batch.support.transaction中的类
Wrapper for a FileChannel that delays actually writing to or closing the buffer if a transaction is active.
TransactionAwareBufferedWriter(FileChannel, Runnable) - 类 的构造器org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Create a new instance with the underlying file channel provided, and a callback to execute on close.
TransactionAwareProxyFactory<T> - org.springframework.batch.support.transaction中的类
Factory for transaction aware objects (like lists, sets, maps).
transactionManager() - 类 中的方法org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
transactionManager() - 类 中的方法org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
transactionManager() - 类 中的方法org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
transactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.core.step.builder.StepBuilderHelper
 
transactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
 
transactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
 
transactionManager(PlatformTransactionManager) - 类 中的方法org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
transform(StepContribution, I) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Responsible for the processing portion of the chunking loop.
transform(StepContribution, I) - 类 中的方法org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Adds retry and skip logic to the process phase of the chunk loop.
transform(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
transform(StepContribution, Chunk<I>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
TransitionBuilder(FlowBuilder<Q>, String) - 类 的构造器org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
 
TRUE_SYMBOL - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
truncate() - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
Truncate the output at the last known good point.

U

unbind(JobFactory, Map<String, ?>) - 类 中的方法org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and unregister it with the JobRegistry.
UncheckedTransactionException - org.springframework.batch.core.step.tasklet中的异常错误
Convenience wrapper for a checked exception so that it can cause a rollback and be extracted afterwards.
UncheckedTransactionException(Exception) - 异常错误 的构造器org.springframework.batch.core.step.tasklet.UncheckedTransactionException
 
UnclosedElementCollectingEventWriter - org.springframework.batch.item.xml.stax中的类
Delegating XMLEventWriter, which collects the QNames of elements that were opened but not closed.
UnclosedElementCollectingEventWriter(XMLEventWriter) - 类 的构造器org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
 
UnexpectedInputException - org.springframework.batch.item中的异常错误
Used to signal an unexpected end of an input or message stream.
UnexpectedInputException(String) - 异常错误 的构造器org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message.
UnexpectedInputException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message and another exception.
UnexpectedJobExecutionException - org.springframework.batch.core中的异常错误
Indicates to the framework that a critical error has occurred and processing should immediately stop.
UnexpectedJobExecutionException(String) - 异常错误 的构造器org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UnexpectedJobExecutionException(String, Throwable) - 异常错误 的构造器org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UNKNOWN - org.springframework.batch.core.BatchStatus
 
UNKNOWN - 类 中的静态变量org.springframework.batch.core.ExitStatus
Convenient constant value representing unknown state - assumed not continuable.
UNKNOWN - 类 中的静态变量org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
unmarshaller(Unmarshaller) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
An implementation of the Unmarshaller from Spring's OXM module.
UnopenedElementClosingEventWriter - org.springframework.batch.item.xml.stax中的类
Delegating XMLEventWriter, which writes EndElement events that match a given collection of QNames directly to the underlying java.io.Writer instead of to the delegate XMLEventWriter.
UnopenedElementClosingEventWriter(XMLEventWriter, Writer, List<QName>) - 类 的构造器org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
 
unregister(String) - 接口 中的方法org.springframework.batch.core.configuration.JobRegistry
Unregisters a previously registered Job.
unregister(String) - 类 中的方法org.springframework.batch.core.configuration.support.MapJobRegistry
 
unregisterStepsFromJob(String) - 接口 中的方法org.springframework.batch.core.configuration.StepRegistry
Unregisters all the steps of the given job.
unregisterStepsFromJob(String) - 类 中的方法org.springframework.batch.core.configuration.support.MapStepRegistry
 
UnterminatedFlowBuilder(FlowBuilder<Q>) - 类 的构造器org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
 
unwrap(Class<T>) - 类 中的方法org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Returns either self or delegate (in this order) if one of them can be cast to supplied parameter class.
update() - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
update(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Update the JobExecution (but not its ExecutionContext).
update(JobExecution) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Update the StepExecution (but not its ExecutionContext).
update(StepExecution) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.core.step.item.ChunkMonitor
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.integration.async.AsyncItemWriter
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.database.HibernateCursorItemReader
Update the context and clear the session if stateful.
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.database.JdbcPagingItemReader
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemReader
Store the current resource index and position in the resource.
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.file.ResourcesItemReader
 
update(ExecutionContext) - 接口 中的方法org.springframework.batch.item.ItemStream
Indicates that the execution context provided during open is about to be saved.
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.ItemStreamSupport
Return empty ExecutionContext.
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.CompositeItemStream
Simple aggregate ExecutionContext provider for the contributions registered under the given key.
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.SingleItemPeekableItemReader
If there is a cached peek, then retrieve the execution context state from that point.
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.support.SynchronizedItemStreamReader
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Get the restart data.
update(ExecutionContext) - 类 中的方法org.springframework.batch.jsr.item.CheckpointSupport
 
update(ExecutionContext) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
update(RepeatContext) - 类 中的方法org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
update(RepeatContext) - 类 中的方法org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
If CheckpointAlgorithm.isReadyToCheckpoint() is true we will call CheckpointAlgorithm.endCheckpoint()
update(RepeatContext) - 接口 中的方法org.springframework.batch.repeat.CompletionPolicy
Give implementations the opportunity to update the state of the current batch.
update(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CompletionPolicySupport
Increment the context so the counter is up to date.
update(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Update all the composed contexts, and also increment the parent context.
update(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
update(RepeatContext) - 类 中的方法org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Increment the counter in the context.
update(RepeatContext) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
UPDATE - org.springframework.batch.sample.domain.trade.CustomerOperation
 
updateCustomer(String, BigDecimal) - 接口 中的方法org.springframework.batch.sample.domain.trade.CustomerDao
 
updateCustomer(String, BigDecimal) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
updateExecutionContext(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given jobExecution.
updateExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContext of the given JobExecution.
updateExecutionContext(JobExecution) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateExecutionContext(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given stepExecution.
updateExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContexts of the given StepExecution.
updateExecutionContext(StepExecution) - 类 中的方法org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateJobExecution(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Update given JobExecution using a SQL UPDATE statement.
updateJobExecution(JobExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.JobExecutionDao
Update and existing JobExecution.
updateJobExecution(JobExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
updateJobExecutionStatus(FlowExecutionStatus) - 接口 中的方法org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed in the JobExecution.
updateJobExecutionStatus(FlowExecutionStatus) - 类 中的方法org.springframework.batch.core.job.flow.JobFlowExecutor
 
updateJobExecutionStatus(FlowExecutionStatus) - 类 中的方法org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
 
updateStepContribution(StepContribution, StepContributionSource) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Update a StepContribution with all the data from a StepContributionSource.
updateStepExecution(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
updateStepExecution(StepExecution) - 类 中的方法org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
updateStepExecution(StepExecution) - 接口 中的方法org.springframework.batch.core.repository.dao.StepExecutionDao
Update the given StepExecution Preconditions: Id must not be null.
updateTotalPrice(List<Trade>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
upgradeStatus(BatchStatus) - 类 中的方法org.springframework.batch.core.JobExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeStatus(BatchStatus) - 类 中的方法org.springframework.batch.core.StepExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeTo(BatchStatus) - 枚举 中的方法org.springframework.batch.core.BatchStatus
Method used to move status values through their logical progression, and override less severe failures with more severe ones.
UPPER_BORDER_NOT_DEFINED - 类 中的静态变量org.springframework.batch.item.file.transform.Range
 
User - org.springframework.batch.sample.domain.mail中的类
 
User() - 类 的构造器org.springframework.batch.sample.domain.mail.User
 
User(int, String, String) - 类 的构造器org.springframework.batch.sample.domain.mail.User
 
UserMailItemProcessor - org.springframework.batch.sample.domain.mail.internal中的类
 
UserMailItemProcessor() - 类 的构造器org.springframework.batch.sample.domain.mail.internal.UserMailItemProcessor
 
useSatelessSession(boolean) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
已过时。
This method is deprecated in favor of HibernatePagingItemReaderBuilder.useStatelessSession(boolean) and will be removed in a future version.
useSharedExtendedConnection(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Indicates that the connection used for the cursor is being used by all other processing, therefor part of the same transaction.
useSharedExtendedConnection(boolean) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates that the connection used for the cursor is being used by all other processing, therefor part of the same transaction.
useStatelessSession(boolean) - 类 中的方法org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Indicator for whether to use a StatelessSession (true) or a Session (false).
useStatelessSession(boolean) - 类 中的方法org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Indicator for whether to use a StatelessSession (true) or a Session (false).

V

validate(Object, Errors) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validate(Object, Errors) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.validator.TradeValidator
 
validate(JobParameters) - 类 中的方法org.springframework.batch.core.job.CompositeJobParametersValidator
Validates the JobParameters according to the injected JobParameterValidators Validation stops and exception is thrown on first validation error
validate(JobParameters) - 类 中的方法org.springframework.batch.core.job.DefaultJobParametersValidator
Check the parameters meet the specification provided.
validate(JobParameters) - 接口 中的方法org.springframework.batch.core.JobParametersValidator
Check the parameters meet whatever requirements are appropriate, and throw an exception if not.
validate(T) - 类 中的方法org.springframework.batch.item.validator.SpringValidator
 
validate(T) - 接口 中的方法org.springframework.batch.item.validator.Validator
Method used to validate if the value is valid.
validateAddress(Address, Errors, String) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validateCustomer(Customer, Errors) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validateFaultTolerantSettings() - 类 中的方法org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Validates that all components required to build a fault tolerant step are set
validateLineItems(List<LineItem>, Errors) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validateOrder(Order, Errors) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validatePayment(BillingInfo, Errors) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validateShipping(ShippingInfo, Errors) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
validateStringLength(String, Errors, String, String, int) - 类 中的方法org.springframework.batch.sample.domain.order.internal.validator.OrderValidator
 
ValidatingItemProcessor<T> - org.springframework.batch.item.validator中的类
Simple implementation of ItemProcessor that validates input and returns it without modifications.
ValidatingItemProcessor() - 类 的构造器org.springframework.batch.item.validator.ValidatingItemProcessor
Default constructor
ValidatingItemProcessor(Validator<? super T>) - 类 的构造器org.springframework.batch.item.validator.ValidatingItemProcessor
Creates a ValidatingItemProcessor based on the given Validator.
ValidationException - org.springframework.batch.item.validator中的异常错误
This exception should be thrown when there are validation errors.
ValidationException(String) - 异常错误 的构造器org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message.
ValidationException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message and another exception.
ValidationSampleConfiguration - org.springframework.batch.sample.validation中的类
 
ValidationSampleConfiguration() - 类 的构造器org.springframework.batch.sample.validation.ValidationSampleConfiguration
 
validator(JobParametersValidator) - 类 中的方法org.springframework.batch.core.job.builder.JobBuilderHelper
Add a job parameters validator.
Validator<T> - org.springframework.batch.item.validator中的接口
Interface used to validate objects.
VALUE_NOT_SET - 类 中的静态变量org.springframework.batch.item.database.AbstractCursorItemReader
 
VALUE_NOT_SET - 类 中的静态变量org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
 
VALUE_NOT_SET - 类 中的静态变量org.springframework.batch.item.database.JdbcPagingItemReader
 
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.BatchStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.JobParameter.ParameterType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.listener.JobListenerMetaData
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.core.listener.StepListenerMetaData
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.item.database.Order
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.item.file.transform.Alignment
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.repeat.RepeatStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.sample.domain.trade.CustomerOperation
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.springframework.batch.support.DatabaseType
返回带有指定名称的该类型的枚举常量。
values() - 枚举 中的静态方法org.springframework.batch.core.BatchStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.core.JobParameter.ParameterType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.core.jsr.JsrJobListenerMetaData
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.core.jsr.JsrStepListenerMetaData
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.core.listener.JobListenerMetaData
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.core.listener.StepListenerMetaData
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.item.database.Order
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.item.file.transform.Alignment
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.repeat.RepeatStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.sample.domain.trade.CustomerOperation
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.springframework.batch.support.DatabaseType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
verifyCursorPosition(boolean) - 类 中的方法org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Indicates if the reader should verify the current position of the ResultSet after being passed to the RowMapper.
verifyCursorPosition(boolean) - 类 中的方法org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates if the reader should verify the current position of the ResultSet after being passed to the RowMapper.
verifyUniquePattern(Element, List<String>, Element, ParserContext) - 类 中的静态方法org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
version(String) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Version of XML to be generated.
VERSION_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
VIP_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
visitBeanDefinition(BeanDefinition) - 类 中的方法org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor.JobLevelBeanLazyInitializer
 

W

waitForResults(RepeatInternalState) - 类 中的方法org.springframework.batch.repeat.support.RepeatTemplate
If necessary, wait for results to come back from remote or concurrent processes.
waitForResults(RepeatInternalState) - 类 中的方法org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Wait for all the results to appear on the queue and execute the after interceptors for each one.
WARN - org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Key for Classifier signalling that the throwable should be logged at warn level.
whereClause(String) - 类 中的方法org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL WHERE clause for a db specific PagingQueryProvider.
whereStatement(String) - 类 中的方法org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
An optional where fragment of the cypher query.
WorkerConfiguration - org.springframework.batch.sample.remotechunking中的类
This configuration class is for the worker side of the remote chunking sample.
WorkerConfiguration - org.springframework.batch.sample.remotepartitioning.aggregating中的类
This configuration class is for the worker side of the remote partitioning sample.
WorkerConfiguration - org.springframework.batch.sample.remotepartitioning.polling中的类
This configuration class is for the worker side of the remote partitioning sample.
WorkerConfiguration() - 类 的构造器org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
WorkerConfiguration(RemotePartitioningWorkerStepBuilderFactory) - 类 的构造器org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
WorkerConfiguration(RemotePartitioningWorkerStepBuilderFactory) - 类 的构造器org.springframework.batch.sample.remotepartitioning.polling.WorkerConfiguration
 
workerIntegrationFlow() - 类 中的方法org.springframework.batch.sample.remotechunking.WorkerConfiguration
 
workerStep() - 类 中的方法org.springframework.batch.sample.remotepartitioning.aggregating.WorkerConfiguration
 
workerStep() - 类 中的方法org.springframework.batch.sample.remotepartitioning.polling.WorkerConfiguration
 
write(char[], int, int) - 类 中的方法org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
write(Object) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
write(String) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
write(List<? extends Object>) - 类 中的方法org.springframework.batch.sample.common.InfiniteLoopWriter
 
write(List<? extends Object>) - 类 中的方法org.springframework.batch.sample.support.DummyItemWriter
 
write(List<? extends Future<T>>) - 类 中的方法org.springframework.batch.integration.async.AsyncItemWriter
In the processing of the Futures passed, nulls are not passed to the delegate since they are considered filtered out by the AsyncItemProcessor's delegated ItemProcessor.
write(List<? extends MimeMessage>) - 类 中的方法org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
 
write(List<? extends Game>) - 类 中的方法org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
write(List<? extends Player>) - 类 中的方法org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
write(List<? extends PlayerSummary>) - 类 中的方法org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
write(List<? extends Person>) - 类 中的方法org.springframework.batch.sample.domain.person.internal.PersonWriter
 
write(List<? extends CustomerCredit>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
 
write(List<? extends CustomerCredit>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
write(List<? extends CustomerCredit>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
write(List<? extends CustomerUpdate>) - 类 中的方法org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
write(List<? extends Trade>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
write(List<? extends Trade>) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
write(List<? extends SimpleMailMessage>) - 类 中的方法org.springframework.batch.item.mail.SimpleMailMessageItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.core.test.timeout.LoggingItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.adapter.ItemWriterAdapter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
Extracts values from item's fields named in fieldsUsedAsTargetMethodArguments and passes them as arguments to the delegate method.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.amqp.AmqpItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.data.MongoItemWriter
If a transaction is active, buffer items to be written just before commit.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.data.Neo4jItemWriter
Write all items to the data store.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.data.RepositoryItemWriter
Write all items to the data store via a Spring Data repository.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.database.HibernateItemWriter
Save or update any entities not in the current hibernate session and then flush the hibernate session.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.database.JdbcBatchItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.database.JpaItemWriter
Merge all provided items that aren't already in the persistence context and then flush the entity manager.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.file.MultiResourceItemWriter
 
write(List<? extends T>) - 接口 中的方法org.springframework.batch.item.ItemWriter
Process the supplied data element.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.jms.JmsItemWriter
Send the items one-by-one to the default destination of the JMS template.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.support.AbstractFileItemWriter
Writes out a string followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.support.ClassifierCompositeItemWriter
Delegates to injected ItemWriter instances according to their classification by the Classifier.
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.support.CompositeItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.support.ListItemWriter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.item.xml.StaxEventItemWriter
Write the value objects and flush them to the file.
write(List<? extends T>) - 类 中的方法org.springframework.batch.jsr.item.ItemWriterAdapter
 
write(List<? extends T>) - 类 中的方法org.springframework.batch.sample.common.StagingItemWriter
Serialize the item to the staging table, and add a NEW processed flag.
write(List<? extends T>) - 类 中的方法org.springframework.batch.sample.support.RetrySampleItemWriter
 
write(List<? extends V>) - 类 中的方法org.springframework.batch.item.KeyValueItemWriter
 
write(XMLEventWriter) - 接口 中的方法org.springframework.batch.item.xml.StaxWriterCallback
Write contents using the supplied XMLEventWriter.
write(StepContribution, Chunk<I>, Chunk<O>) - 类 中的方法org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
write(StepContribution, Chunk<I>, Chunk<O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
Simple implementation delegates to the SimpleChunkProcessor.doWrite(List) method and increments the write count in the contribution.
write(CustomerDebit) - 接口 中的方法org.springframework.batch.sample.domain.trade.CustomerDebitDao
 
write(CustomerDebit) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
writeCredit(CustomerCredit) - 接口 中的方法org.springframework.batch.sample.domain.trade.CustomerCreditDao
 
writeCredit(CustomerCredit) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
writeCredit(CustomerCredit) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
WriteFailedException - org.springframework.batch.item中的异常错误
Unchecked exception indicating that an error has occurred while trying to clear a buffer on a rollback.
WriteFailedException(String) - 异常错误 的构造器org.springframework.batch.item.WriteFailedException
Create a new WriteFailedException based on a message.
WriteFailedException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.WriteFailedException
Create a new WriteFailedException based on a message and another exception.
writeFooter(Writer) - 接口 中的方法org.springframework.batch.item.file.FlatFileFooterCallback
Write contents to a file using the supplied Writer.
writeFooter(Writer) - 类 中的方法org.springframework.batch.sample.support.SummaryFooterCallback
 
writeHeader(Writer) - 接口 中的方法org.springframework.batch.item.file.FlatFileHeaderCallback
Write contents to a file using the supplied Writer.
writeHeader(Writer) - 类 中的方法org.springframework.batch.sample.support.HeaderCopyCallback
 
writeItems(List<Object>) - 类 中的方法org.springframework.batch.sample.jsr352.JsrSampleItemWriter
 
writeItems(List<O>) - 类 中的方法org.springframework.batch.core.step.item.SimpleChunkProcessor
 
writeKeyValue(K, V) - 类 中的方法org.springframework.batch.item.data.GemfireItemWriter
 
writeKeyValue(K, V) - 类 中的方法org.springframework.batch.item.KeyValueItemWriter
Subclasses implement this method to write each item to key value store
writer() - 类 中的方法org.springframework.batch.sample.config.RetrySampleConfiguration
 
writer(ItemWriter<? super O>) - 类 中的方法org.springframework.batch.core.step.builder.SimpleStepBuilder
An item writer that writes a chunk of items.
writer(ItemWriter<? super O>) - 类 中的方法org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
This method will throw a UnsupportedOperationException since the item writer of the master step in a remote chunking setup will be automatically set to an instance of ChunkMessageChannelItemWriter.
WriterNotOpenException - org.springframework.batch.item中的异常错误
Exception indicating that an ItemWriter needed to be opened before being written to.
WriterNotOpenException(String) - 异常错误 的构造器org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message.
WriterNotOpenException(String, Throwable) - 异常错误 的构造器org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message and another exception.
writeTrade(Trade) - 类 中的方法org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
writeTrade(Trade) - 接口 中的方法org.springframework.batch.sample.domain.trade.TradeDao
 

X

xmlInputFactory(XMLInputFactory) - 类 中的方法org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Set the XMLInputFactory.
XStreamExecutionContextStringSerializer - org.springframework.batch.core.repository.dao中的类
已过时。
Due to the incompatibilities between current Jettison versions and XStream versions, this serializer is deprecated in favor of Jackson2ExecutionContextStringSerializer
XStreamExecutionContextStringSerializer() - 类 的构造器org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
已过时。
 

Z

ZERO - 类 中的静态变量org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
ZIP_CODE_COLUMN - 类 中的静态变量org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z 
所有类 所有程序包