- Kafka - Class in org.springframework.integration.kafka.dsl
 
- 
Factory class for Apache Kafka components.
 
- KafkaAckCallback(KafkaMessageSource.KafkaAckInfo<K, V>, ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
- 
Construct an instance with the provided properties.
 
- KafkaAckCallbackFactory(ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 
- 
Construct an instance with the provided properties.
 
- KafkaChannelParser - Class in org.springframework.integration.kafka.config.xml
 
- 
Parser for a channel backed by a Kafka topic.
 
- KafkaChannelParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaChannelParser
 
-  
 
- KafkaInboundChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
 
- 
Parser for the inbound channel adapter.
 
- KafkaInboundChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 
-  
 
- KafkaInboundChannelAdapterSpec<K,V> - Class in org.springframework.integration.kafka.dsl
 
- 
Spec for a polled Kafka inbound channel adapter.
 
- KafkaInboundGateway<K,V,R> - Class in org.springframework.integration.kafka.inbound
 
- 
Inbound gateway.
 
- KafkaInboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
Construct an instance with the provided container.
 
- KafkaInboundGatewayParser - Class in org.springframework.integration.kafka.config.xml
 
- 
Inbound gateway parser.
 
- KafkaInboundGatewayParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
-  
 
- KafkaInboundGatewaySpec<K,V,R,S extends KafkaInboundGatewaySpec<K,V,R,S>> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaIntegrationHeaders - Class in org.springframework.integration.kafka.support
 
- 
Headers specifically for Spring Integration components.
 
- KafkaMessageDrivenChannelAdapter<K,V> - Class in org.springframework.integration.kafka.inbound
 
- 
Message-driven channel adapter.
 
- KafkaMessageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
 
- KafkaMessageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Construct an instance with the provided mode.
 
- KafkaMessageDrivenChannelAdapter.ListenerMode - Enum in org.springframework.integration.kafka.inbound
 
- 
The listener mode for the container, record or batch.
 
- KafkaMessageDrivenChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
 
- 
Parser for the message driven channel adapter.
 
- KafkaMessageDrivenChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
 
-  
 
- KafkaMessageDrivenChannelAdapterSpec<K,V,S extends KafkaMessageDrivenChannelAdapterSpec<K,V,S>> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec<K,V> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaMessageListenerContainerSpec<K,V> - Class in org.springframework.integration.kafka.dsl
 
- 
A helper class in the Builder pattern style to delegate options to the
 ConcurrentMessageListenerContainer.
 
- KafkaMessageSource<K,V> - Class in org.springframework.integration.kafka.inbound
 
- 
Polled message source for kafka.
 
- KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Construct an instance with the supplied parameters.
 
- KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, boolean) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Construct an instance with the supplied parameters.
 
- KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Construct an instance with the supplied parameters.
 
- KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, boolean) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Construct an instance with the supplied parameters.
 
- KafkaMessageSource.KafkaAckCallback<K,V> - Class in org.springframework.integration.kafka.inbound
 
- 
AcknowledgmentCallback for Kafka.
 
- KafkaMessageSource.KafkaAckCallbackFactory<K,V> - Class in org.springframework.integration.kafka.inbound
 
- 
AcknowledgmentCallbackFactory for KafkaAckInfo.
 
- KafkaMessageSource.KafkaAckInfo<K,V> - Interface in org.springframework.integration.kafka.inbound
 
- 
Information for building an KafkaAckCallback.
 
- KafkaMessageSource.KafkaAckInfoImpl - Class in org.springframework.integration.kafka.inbound
 
- 
Information for building an KafkaAckCallback.
 
- KafkaNamespaceHandler - Class in org.springframework.integration.kafka.config.xml
 
- 
The namespace handler for the Kafka namespace.
 
- KafkaNamespaceHandler() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
 
-  
 
- KafkaOutboundChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
 
- 
Parser for the outbound channel adapter.
 
- KafkaOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaOutboundChannelAdapterParser
 
-  
 
- KafkaOutboundGatewayParser - Class in org.springframework.integration.kafka.config.xml
 
- 
Parser for the outbound gateway.
 
- KafkaOutboundGatewayParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
-  
 
- KafkaOutboundGatewaySpec<K,V,R,S extends KafkaOutboundGatewaySpec<K,V,R,S>> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
 
- 
An IntegrationComponentSpec
 implementation for the KafkaTemplate.
 
- KafkaParsingUtils - Class in org.springframework.integration.kafka.config.xml
 
- 
Utilities to assist with parsing XML.
 
- KafkaPointToPointChannelSpec - Class in org.springframework.integration.kafka.dsl
 
- 
Spec for a point to point channel backed by a Kafka topic.
 
- KafkaPointToPointChannelSpec(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPointToPointChannelSpec
 
-  
 
- KafkaPollableChannelSpec - Class in org.springframework.integration.kafka.dsl
 
- 
Spec for a pollable channel.
 
- KafkaPollableChannelSpec(KafkaTemplate<?, ?>, KafkaMessageSource<?, ?>) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPollableChannelSpec
 
-  
 
- KafkaProducerMessageHandler<K,V> - Class in org.springframework.integration.kafka.outbound
 
- 
Kafka Message Handler; when supplied with a ReplyingKafkaTemplate it is used as
 the handler in an outbound gateway.
 
- KafkaProducerMessageHandler(KafkaTemplate<K, V>) - Constructor for class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
-  
 
- KafkaProducerMessageHandler.ProducerRecordCreator<K,V> - Interface in org.springframework.integration.kafka.outbound
 
- 
Creates a ProducerRecord from a Message and/or properties
 derived from configuration and/or the message.
 
- KafkaProducerMessageHandlerSpec<K,V,S extends KafkaProducerMessageHandlerSpec<K,V,S>> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec<K,V> - Class in org.springframework.integration.kafka.dsl
 
- 
 
- KafkaPublishSubscribeChannelSpec - Class in org.springframework.integration.kafka.dsl
 
- 
Spec for a publish/subscribe channel backed by a Kafka topic.
 
- KafkaPublishSubscribeChannelSpec(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPublishSubscribeChannelSpec
 
-  
 
- KafkaSendFailureException - Exception in org.springframework.integration.kafka.support
 
- 
An exception that is the payload of an ErrorMessage when a send fails.
 
- KafkaSendFailureException(Message<?>, ProducerRecord<?, ?>, Throwable) - Constructor for exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
-  
 
- KafkaSubscribableChannelSpec<C extends SubscribableKafkaChannel> - Class in org.springframework.integration.kafka.dsl
 
- 
Spec for a subscribable channel.
 
- KafkaSubscribableChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.KafkaSubscribableChannelSpec
 
-  
 
- KafkaTemplateSpec<K,V> - Class in org.springframework.integration.kafka.dsl
 
- 
An IntegrationComponentSpec implementation for the KafkaTemplate.
 
- sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 
- 
Set the channel to which failed send results are sent.
 
- sendFailureChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 
- 
Set the channel to which failed send results are sent.
 
- sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 
- 
Set the channel to which successful send results are sent.
 
- sendSuccessChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 
- 
Set the channel to which successful send results are sent.
 
- sendTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 
- 
 
- setAckDeferred(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
-  
 
- setAckDeferred(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
-  
 
- setAckDiscarded(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
A boolean flag to indicate if FilteringMessageListenerAdapter
 should acknowledge discarded records or not.
 
- setAutoStartup(boolean) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
- 
Set the auto startup.
 
- setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Set the message converter to use with a batch-based consumer.
 
- setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
Set to true to bind the source consumer record in the header named
 IntegrationMessageHeaderAccessor.SOURCE_DATA.
 
- setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Set to true to bind the source consumer record in the header named
 IntegrationMessageHeaderAccessor.SOURCE_DATA.
 
- setCloseTimeout(Duration) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Set the close timeout - default 30 seconds.
 
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the error message strategy implementation to use when sending error messages after
 send failures.
 
- setFilterInRetry(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
The boolean flag to specify the order how
 RetryingMessageListenerAdapter and
 FilteringMessageListenerAdapter are wrapped to each other,
 if both of them are present.
 
- setFlushExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Specify a SpEL expression that evaluates to a Boolean to determine whether
 the producer should be flushed after the send.
 
- setFuturesChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the futures channel.
 
- setFuturesChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the futures channel name.
 
- setGroupId(String) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 
- 
Set the group id for the consumer; if not set, the bean name will be used.
 
- setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the header mapper to use.
 
- setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 
-  
 
- setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
Set the message converter; must be a RecordMessageConverter or
 BatchMessageConverter depending on mode.
 
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Set the message converter; must be a RecordMessageConverter or
 BatchMessageConverter depending on mode.
 
- setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Set the message converter to replace the default
 MessagingMessageConverter.
 
- setMessageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
-  
 
- setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
Specify a BiConsumer for seeks management during
 ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
 call from the KafkaMessageListenerContainer.
 
- setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Specify a BiConsumer for seeks management during
 ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)
 call from the KafkaMessageListenerContainer.
 
- setPartitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
-  
 
- setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
When using a type-aware message converter (such as StringJsonMessageConverter,
 set the payload type the converter should create.
 
- setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
When using a type-aware message converter (such as StringJsonMessageConverter,
 set the payload type the converter should create.
 
- setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Set the payload type.
 
- setPhase(int) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
- 
Set the phase.
 
- setProducerRecordCreator(KafkaProducerMessageHandler.ProducerRecordCreator<K, V>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
 
- setRawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
- 
Set to true to include the raw ConsumerRecord as headers with keys
 KafkaHeaders.RAW_DATA and
 IntegrationMessageHeaderAccessor.SOURCE_DATA.
 
- setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Specify a RecordFilterStrategy to wrap
 KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into
 FilteringMessageListenerAdapter.
 
- setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Set the message converter to use with a record-based consumer.
 
- setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
A RecoveryCallback instance for retry operation;
 if null, the exception will be thrown to the container after retries are exhausted
 (unless an error channel is configured).
 
- setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
A RecoveryCallback instance for retry operation;
 if null, the exception will be thrown to the container after retries are exhausted
 (unless an error channel is configured).
 
- setReplyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set a message converter for gateway replies.
 
- setReplyPayloadType(Type) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
When using a type-aware message converter (such as StringJsonMessageConverter,
 set the payload type the converter should create.
 
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
- 
Specify a RetryTemplate instance to wrap
 KafkaInboundGateway.IntegrationRecordMessageListener into
 RetryingMessageListenerAdapter.
 
- setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
- 
Specify a RetryTemplate instance to wrap
 KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into
 RetryingMessageListenerAdapter.
 
- setRolledBack(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 
-  
 
- setRolledBack(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
-  
 
- setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the failure channel.
 
- setSendFailureChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the failure channel name.
 
- setSendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the success channel.
 
- setSendSuccessChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set the Success channel name.
 
- setSendTimeout(long) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
 
- setSendTimeoutExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Specify a SpEL expression to evaluate a timeout in milliseconds for how long this
 
KafkaProducerMessageHandler should wait wait for send operation results.
 
 
- setSync(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
 
- setTimeoutBuffer(int) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Set a buffer, in milliseconds, added to the configured 
delivery.timeout.ms
 to determine the minimum time to wait for the send future completion when
 
sync is true.
 
 
- setTimestampExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
- 
Specify a SpEL expression to evaluate a timestamp that will be added in the Kafka record.
 
- setTopicExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
-  
 
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 
-  
 
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 
-  
 
- shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 
-  
 
- shutdownTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 
- 
Set the timeout for shutting down the container.
 
- start() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
-  
 
- start() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
-  
 
- start() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
-  
 
- stop() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
-  
 
- stop(Runnable) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
-  
 
- stop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
-  
 
- stop() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
-  
 
- SubscribableKafkaChannel - Class in org.springframework.integration.kafka.channel
 
- 
Subscribable channel backed by a Kafka topic.
 
- SubscribableKafkaChannel(KafkaOperations<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
- 
Construct an instance with the provided parameters.
 
- subscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
-  
 
- sync(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 
- 
 
- syncCommits(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 
- 
Set whether or not to call consumer.commitSync() or commitAsync() when the
 container is responsible for commits.