@PublicEvolving public class SourceConfiguration extends Object implements Serializable
Constructor and Description |
---|
SourceConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
boolean |
equals(Object o) |
long |
getAutoCommitCursorInterval()
The interval in millis for acknowledge message when you enable
isEnableAutoAcknowledgeMessage() and use SubscriptionType.Failover or SubscriptionType.Exclusive as your consuming subscription type. |
int |
getMaxFetchRecords()
The fetch counts for a split reader.
|
java.time.Duration |
getMaxFetchTime()
The fetch time for flink split reader polling message.
|
int |
getMessageQueueCapacity()
The capacity of the element queue in the source reader.
|
long |
getPartitionDiscoveryIntervalMs()
The interval in millis for flink querying topic partition information.
|
String |
getSubscriptionDesc()
Convert the subscription into a readable str.
|
org.apache.pulsar.client.api.SubscriptionMode |
getSubscriptionMode()
The pulsar's subscription mode for this flink source.
|
String |
getSubscriptionName()
The pulsar's subscription name for this flink source.
|
org.apache.pulsar.client.api.SubscriptionType |
getSubscriptionType()
The pulsar's subscription type for this flink source.
|
long |
getTransactionTimeoutMillis()
Pulsar's transaction have a timeout mechanism for uncommitted transaction.
|
CursorVerification |
getVerifyInitialOffsets()
Validate the
CursorPosition generated by StartCursor . |
int |
hashCode() |
boolean |
isEnableAutoAcknowledgeMessage()
This is used for all subscription type.
|
boolean |
isEnablePartitionDiscovery()
We would override the interval into a negative number when we set the connector with bounded
stop cursor.
|
public SourceConfiguration(Configuration configuration)
public int getMessageQueueCapacity()
public boolean isEnablePartitionDiscovery()
public long getPartitionDiscoveryIntervalMs()
public boolean isEnableAutoAcknowledgeMessage()
SubscriptionType.Shared
and SubscriptionType.Key_Shared
would
immediately acknowledge the message after consuming it.
SubscriptionType.Failover
and SubscriptionType.Exclusive
would perform
a incremental acknowledge in a fixed getAutoCommitCursorInterval()
.
public long getAutoCommitCursorInterval()
isEnableAutoAcknowledgeMessage()
and use SubscriptionType.Failover
or SubscriptionType.Exclusive
as your consuming subscription type.public long getTransactionTimeoutMillis()
SubscriptionType.Shared
and SubscriptionType.Key_Shared
when user disable
isEnableAutoAcknowledgeMessage()
and enable flink checkpoint. Since the checkpoint
interval couldn't be acquired from SourceReaderContext.getConfiguration()
, we have to
expose this option. Make sure this value is greater than the checkpoint interval.public java.time.Duration getMaxFetchTime()
RecordsWithSplitIds
when timeout or exceed the getMaxFetchRecords()
.public int getMaxFetchRecords()
RecordsWithSplitIds
when timeout getMaxFetchTime()
or exceed this value.public CursorVerification getVerifyInitialOffsets()
CursorPosition
generated by StartCursor
.public String getSubscriptionName()
ConsumerBuilder.subscriptionName(java.lang.String)
public org.apache.pulsar.client.api.SubscriptionType getSubscriptionType()
SubscriptionType
public org.apache.pulsar.client.api.SubscriptionMode getSubscriptionMode()
SubscriptionMode
public String getSubscriptionDesc()
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.