インデックス

A B C D E F G H I J K L M N O P R S T U V W Z
すべてのクラスとインターフェース | すべてのパッケージ | 定数フィールド値 | 直列化された形式

P

parentOrThis() - クラス org.springframework.kafka.listener のメソッド。AbstractMessageListenerContainer
これまたはこれに親がある場合は親コンテナーを返します。
parentOrThis() - クラス org.springframework.kafka.listener のメソッド。KafkaMessageListenerContainer
parseBooleanProperty(String) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
指定されたプロパティが環境またはシステムのプロパティに存在する場合は、解析された値を返します。
PARSER_CONTEXT - Static variable in class org.springframework.kafka.listener.adapter.AdapterUtils
! を使用したランタイム SpEL のパーサーコンテキストテンプレートプレフィックス。
ParseStringDeserializer< T > - Class in org.springframework.kafka.support.serializer
Kafka から受信した StringSE 表現からエンティティを逆直列化するための汎用 Deserializer (別名、解析)。
ParseStringDeserializer() - クラス org.springframework.kafka.support.serializer. ParseStringDeserializer のコンストラクター
パーサー関数を使用せずにインスタンスを作成します。静的メソッド名は、コンシューマー構成の ParseStringDeserializer.KEY_PARSER または ParseStringDeserializer.VALUE_PARSER プロパティで指定する必要があります。
ParseStringDeserializer(BiFunction<String, Headers, T>) - クラス org.springframework.kafka.support.serializer. ParseStringDeserializer のコンストラクター
提供されているパーサー関数を使用してインスタンスを構築します。
ParseStringDeserializer(Function<String, T>) - クラス org.springframework.kafka.support.serializer. ParseStringDeserializer のコンストラクター
提供されているパーサー関数を使用してインスタンスを構築します。
PARTIAL_RESULTS_AFTER_TIMEOUT_TOPIC - Static variable in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
集約された結果を持つ「外部」 ConsumerRecord の疑似トピック名は、タイムアウト後の値になります。
partition() - Element in annotation interface org.springframework.kafka.annotation.PartitionOffset
リッスンするトピック内のパーティション。
partition() - クラス org.springframework.kafka.listener.adapter のメソッド。ConsumerRecordMetadata
partition(int) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
PARTITION - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
失敗したレコードを受信したパーティション。
PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
Kafka にデータを送信するときのトピックパーティションを含むヘッダー。
partitionHeader(String) - クラス org.springframework.kafka.listener のメソッド。DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
元のレコードのパーティションを格納するために使用されるヘッダーの名前を設定します。
PartitionOffset - Annotation Interface in org.springframework.kafka.annotation
KafkaListener にパーティション / 初期オフセット情報を追加するために使用されます。
partitionOffsets() - Element in annotation interface org.springframework.kafka.annotation.TopicPartition
トピック内の初期オフセットを持つパーティション。
partitions() - Element in annotation interface org.springframework.kafka.annotation.TopicPartition
トピック内のパーティション。
partitions() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
partitions(int) - クラス org.springframework.kafka.config のメソッド。TopicBuilder
パーティションの数を設定します(デフォルトのブローカー 'num.partitions' )。
PARTITIONS_PROPERTY_NAME - Static variable in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
埋め込みブローカーで作成するトピックのパーティションの数。
partitionsFor(String) - クラス org.springframework.kafka.core のメソッド。DefaultKafkaProducerFactory.CloseSafeProducer
partitionsFor(String) - インターフェース org.springframework.kafka.core のメソッド。KafkaOperations
Producer.partitionsFor(String) を参照してください。
partitionsFor(String) - クラス org.springframework.kafka.core のメソッド。KafkaTemplate
partitionsFromConsumerFor(String) - クラス org.springframework.kafka.core.reactive のメソッド。ReactiveKafkaConsumerTemplate
partitionsFromProducerFor(String) - クラス org.springframework.kafka.core.reactive のメソッド。ReactiveKafkaProducerTemplate
pause() - クラス org.springframework.kafka.listener のメソッド。AbstractMessageListenerContainer
pause() - クラス org.springframework.kafka.listener のメソッド。ConcurrentMessageListenerContainer
pause() - クラス org.springframework.kafka.listener のメソッド。KafkaMessageListenerContainer
pause() - インターフェース org.springframework.kafka.listener のメソッド。MessageListenerContainer
次の poll() の前に、このコンテナーを一時停止します。
pause(String, Duration) - クラス org.springframework.kafka.listener のメソッド。ListenerContainerPauseService
指定された ID でリスナーを一時停止します。
pause(TopicPartition...) - クラス org.springframework.kafka.core.reactive のメソッド。ReactiveKafkaConsumerTemplate
pause(MessageListenerContainer, Duration) - クラス org.springframework.kafka.listener のメソッド。ListenerContainerPauseService
指定されたコンテナーインスタンスによってリスナーを一時停止します。
paused() - クラス org.springframework.kafka.core.reactive のメソッド。ReactiveKafkaConsumerTemplate
pausePartition(TopicPartition) - クラス org.springframework.kafka.listener のメソッド。AbstractMessageListenerContainer
pausePartition(TopicPartition) - クラス org.springframework.kafka.listener のメソッド。ConcurrentMessageListenerContainer
pausePartition(TopicPartition) - インターフェース org.springframework.kafka.listener のメソッド。MessageListenerContainer
次の poll() の前にこのパーティションを一時停止します。
pausePartition(MessageListenerContainer, TopicPartition, Duration) - クラス org.springframework.kafka.listener のメソッド。ListenerContainerPauseService
期間中、特定のパーティションからの消費を一時停止します。
ports() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
kafka ブローカーがリッスンする明示的なポートを設定します。
PORTS_PROPERTY_NAME - Static variable in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
組み込みブローカーを公開するポート。
position(TopicPartition) - クラス org.springframework.kafka.core.reactive のメソッド。ReactiveKafkaConsumerTemplate
postProcess(C) - インターフェース org.springframework.kafka.config のメソッド。ContainerPostProcessor
コンテナーの後処理を行います。
postProcessAfterInitialization(Object, String) - クラス org.springframework.kafka.annotation のメソッド。KafkaListenerAnnotationBeanPostProcessor
postProcessBeforeInitialization(Object, String) - クラス org.springframework.kafka.annotation のメソッド。KafkaListenerAnnotationBeanPostProcessor
PREFIX - Static variable in class org.springframework.kafka.support.KafkaHeaders
Kafka ヘッダーのプレフィックス。
primary() - Method in class org.springframework.kafka.core.ABSwitchCluster
プライマリクラスターを使用します。
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - インターフェース org.springframework.kafka.listener のメソッド。AfterRollbackProcessor
残りのレコードを処理します。
process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - クラス org.springframework.kafka.listener のメソッド。DefaultAfterRollbackProcessor
process(Record<K, V>) - クラス org.springframework.kafka.streams のメソッド。HeaderEnricherProcessor
process(Record<Kin, Vin>) - クラス org.springframework.kafka.streams.messaging のメソッド。MessagingProcessor
process(MethodKafkaListenerEndpoint<?, ?>) - インターフェース org.springframework.kafka.retrytopic のメソッド。RetryTopicConfigurer.EndpointProcessor
processAheadOfTime(RegisteredBean) - クラス org.springframework.kafka.aot のメソッド。KafkaAvroBeanRegistrationAotProcessor
processAnnotation(String[], Class<?>, RetryableTopic, Object) - クラス org.springframework.kafka.annotation のメソッド。RetryableTopicAnnotationProcessor
processAnnotation(String[], Method, RetryableTopic, Object) - クラス org.springframework.kafka.annotation のメソッド。RetryableTopicAnnotationProcessor
processBatch(ConsumerRecords<K, V>, List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - インターフェース org.springframework.kafka.listener のメソッド。AfterRollbackProcessor
レコードのバッチ全体を処理します。
processBatch(ConsumerRecords<K, V>, List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - クラス org.springframework.kafka.listener のメソッド。DefaultAfterRollbackProcessor
processDestinationTopicProperties(Consumer<DestinationTopic.Properties>, DestinationTopicProcessor.Context) - クラス org.springframework.kafka.retrytopic のメソッド。DefaultDestinationTopicProcessor
processDestinationTopicProperties(Consumer<DestinationTopic.Properties>, DestinationTopicProcessor.Context) - インターフェース org.springframework.kafka.retrytopic のメソッド。DestinationTopicProcessor
宛先プロパティを処理します。
processKafkaListener(KafkaListener, Method, Object, String) - クラス org.springframework.kafka.annotation のメソッド。KafkaListenerAnnotationBeanPostProcessor
processListener(MethodKafkaListenerEndpoint<?, ?>, KafkaListener, Object, String, String[], TopicPartitionOffset[]) - クラス org.springframework.kafka.annotation のメソッド。KafkaListenerAnnotationBeanPostProcessor
processMainAndRetryListeners(RetryTopicConfigurer.EndpointProcessor, MethodKafkaListenerEndpoint<?, ?>, RetryTopicConfiguration, KafkaListenerEndpointRegistrar, KafkaListenerContainerFactory<?>, String) - クラス org.springframework.kafka.retrytopic のメソッド。RetryTopicConfigurer
再試行エンドポイントと dlt エンドポイントを作成および構成するためのエントリポイントと、対応する listenerContainer を作成するコンテナーファクトリ。
processRegisteredDestinations(Consumer<Collection<String>>, DestinationTopicProcessor.Context) - クラス org.springframework.kafka.retrytopic のメソッド。DefaultDestinationTopicProcessor
processRegisteredDestinations(Consumer<Collection<String>>, DestinationTopicProcessor.Context) - インターフェース org.springframework.kafka.retrytopic のメソッド。DestinationTopicProcessor
登録された宛先を処理します。
producerAdded(String, Producer<K, V>) - クラス org.springframework.kafka.core のメソッド。MicrometerProducerListener
producerAdded(String, Producer<K, V>) - インターフェース org.springframework.kafka.core のメソッド。ProducerFactory.Listener
新しいプロデューサーが作成されました。
ProducerFactory< K , V > - Interface in org.springframework.kafka.core
Producer インスタンスを生成する戦略。
ProducerFactory.Listener < K , V > - Interface in org.springframework.kafka.core
プロデューサーが追加または削除されるたびに呼び出されます。
ProducerFactoryUtils - org.springframework.kafka.core のクラス
Spring ベースの Kafka DefaultKafkaProducerFactory を管理するためのヘルパークラス、特に特定の ProducerFactory のトランザクション Kafka リソースを取得するためのクラス。
ProducerListener< K , V > - Interface in org.springframework.kafka.support
送信 Kafka メッセージを処理するためのリスナー。
ProducerPostProcessor< K , V > - Interface in org.springframework.kafka.core
新しく作成されたプロデューサーに対して後処理を実行するために、プロデューサーファクトリによって呼び出されます。
producerProps(String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
<Integer, String> プロデューサーのテストプロパティを設定します。
producerProps(EmbeddedKafkaBroker) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
<Integer, String> プロデューサーのテストプロパティを設定します。
producerRemoved(String, Producer<K, V>) - クラス org.springframework.kafka.core のメソッド。MicrometerProducerListener
producerRemoved(String, Producer<K, V>) - インターフェース org.springframework.kafka.core のメソッド。ProducerFactory.Listener
既存のプロデューサーが削除されました。
ProjectingMessageConverter - org.springframework.kafka.support.converter のクラス
Spring Data ProjectionFactory を使用して受信メッセージを射影インターフェースにバインドする MessageConverter 実装。
ProjectingMessageConverter() - クラス org.springframework.kafka.support.converter. ProjectingMessageConverter のコンストラクター
デフォルトで JacksonUtils.enhancedObjectMapper() を使用して新しい ProjectingMessageConverter を作成します。
ProjectingMessageConverter(ObjectMapper) - クラス org.springframework.kafka.support.converter. ProjectingMessageConverter のコンストラクター
指定された ObjectMapper を使用して新しい ProjectingMessageConverter を作成します。
ProjectingMessageConverter(ObjectMapper, MessagingMessageConverter) - クラス org.springframework.kafka.support.converter. ProjectingMessageConverter のコンストラクター
指定された ObjectMapper を使用して新しい ProjectingMessageConverter を作成します。
ProjectingMessageConverter(MessagingMessageConverter) - クラス org.springframework.kafka.support.converter. ProjectingMessageConverter のコンストラクター
指定された ObjectMapper を使用して新しい ProjectingMessageConverter を作成します。
properties - Variable in class org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
properties() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
Kafka コンシューマープロパティ ; それらは、コンシューマーファクトリで定義された同じ名前のプロパティに優先します(コンシューマーファクトリがプロパティのオーバーライドをサポートしている場合)。
Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long) - クラス org.springframework.kafka.retrytopic のコンストラクター。DestinationTopic.Properties
DLT コンテナーが自動的に起動するように、提供されたプロパティを使用してインスタンスを作成します(コンテナーファクトリがそのように構成されている場合)。
Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long, Boolean) - クラス org.springframework.kafka.retrytopic のコンストラクター。DestinationTopic.Properties
提供されたプロパティでインスタンスを作成します。
Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long, Boolean, Set<Class<? extends Throwable>>) - クラス org.springframework.kafka.retrytopic のコンストラクター。DestinationTopic.Properties
提供されたプロパティでインスタンスを作成します。
Properties(DestinationTopic.Properties, String, DestinationTopic.Type) - クラス org.springframework.kafka.retrytopic のコンストラクター。DestinationTopic.Properties
DLT コンテナーが自動的に起動する状態で、提供されたプロパティを使用してインスタンスを作成します。
propertiesFromConsumerPropertyOverrides() - クラス org.springframework.kafka.listener のメソッド。AbstractMessageListenerContainer
デフォルトのコンシューマーオーバーライドプロパティを明示的なプロパティにします。
propertyToMethodInvokingFunction(String, Class<P>, ClassLoader) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
プロパティ値 (FQCN.methodName) を、ペイロードとヘッダーを受け取り、何らかの値を返す BiFunctionSE に変換します。
provide(ListenerMetadata, long) - インターフェース org.springframework.kafka.listener のメソッド。OffsetAndMetadataProvider
指定されたリスナーのメタデータとオフセットのオフセットとメタデータオブジェクトを提供します。
publish(ProducerRecord<Object, Object>, KafkaOperations<Object, Object>, ConsumerRecord<?, ?>) - クラス org.springframework.kafka.listener のメソッド。DeadLetterPublishingRecoverer
送信結果のログ記録以上のものが必要な場合は、これをオーバーライドします。
publishConsumerPausedEvent(Collection<TopicPartition>, String) - インターフェース org.springframework.kafka.listener のメソッド。ConsumerPauseResumeEventPublisher
コンシューマー一時停止イベントを発行します。
publishConsumerPausedEvent(Collection<TopicPartition>, String) - クラス org.springframework.kafka.listener のメソッド。KafkaMessageListenerContainer
publishConsumerResumedEvent(Collection<TopicPartition>) - インターフェース org.springframework.kafka.listener のメソッド。ConsumerPauseResumeEventPublisher
コンシューマー再開イベントを発行します。
publishConsumerResumedEvent(Collection<TopicPartition>) - クラス org.springframework.kafka.listener のメソッド。KafkaMessageListenerContainer
publishContainerStoppedEvent() - クラス org.springframework.kafka.listener のメソッド。AbstractMessageListenerContainer
A B C D E F G H I J K L M N O P R S T U V W Z
すべてのクラスとインターフェース | すべてのパッケージ | 定数フィールド値 | 直列化された形式