Skip navigation links
A B C D E F G I K L M N O P R S T V W 

A

AbstractPartition<K,V> - Class in org.thales.punch.kafka.impl
Our IPartition abstract implementation.
AbstractPartition(KafkaConsumer<K, V>, IMetricContext, String, int, Long) - Constructor for class org.thales.punch.kafka.impl.AbstractPartition
 
ack(long) - Method in interface org.thales.punch.kafka.api.IPartition
Optional operation.
ack(long) - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
 
action - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
add(long) - Method in class org.thales.punch.kafka.impl.OffsetTree
Add an offset to the tree.
ADMIN_READER_CLIENT_ID - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
 
ADMIN_READER_GROUP_ID - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
 
ADMIN_READER_GROUP_ID_PREFIX - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
Group identifier used by admin apps that only consult the platform status topic.
ADMIN_READER_WRITER_CLIENT_ID - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
All admin command lines or application use the same client id so as to always read the latest unique platform status document, and to not have kafka keep track of transient client every time an admin command is launched.
ADMIN_READER_WRITER_GROUP_ID - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
All admin command lines or application use the same group id to make sure only one has control over the admin topic.
ADMIN_STATE_KEY - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
The key associated to each published admin status record.
ApplicationControlRecordPojo - Class in org.thales.punch.kafka.application
This pojo is used to exchange exit notifications and informations between the application and the admin service.
ApplicationControlRecordPojo() - Constructor for class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
ApplicationExitControllerImpl - Class in org.thales.punch.kafka.application
The exit controller watch a kafka topic and report to you these application you need to monitor to be told upon their wish to exit.
ApplicationExitControllerImpl(String, IMetricContext) - Constructor for class org.thales.punch.kafka.application.ApplicationExitControllerImpl
Ctor.
ApplicationExitReporterImpl - Class in org.thales.punch.kafka.application
 
ApplicationExitReporterImpl(ApplicationEnv) - Constructor for class org.thales.punch.kafka.application.ApplicationExitReporterImpl
 
applicationName - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
applications_size - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
ApplicationStartReporterImpl - Class in org.thales.punch.kafka.application
 
ApplicationStartReporterImpl(String, String) - Constructor for class org.thales.punch.kafka.application.ApplicationStartReporterImpl
 
applicationUuid - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
ASSIGNEMENT_V1 - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
A leader has been elected.
attach(Object) - Method in interface org.thales.punch.kafka.api.IPartition
Attach an object to this partition.
attach(Object) - Method in class org.thales.punch.kafka.impl.AbstractPartition
 

B

BookActiveReporterImpl - Class in org.thales.punch.kafka.application
 
BookActiveReporterImpl() - Constructor for class org.thales.punch.kafka.application.BookActiveReporterImpl
 
BookExitReporterImpl - Class in org.thales.punch.kafka.application
 
BookExitReporterImpl() - Constructor for class org.thales.punch.kafka.application.BookExitReporterImpl
 
build() - Method in class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 

C

checkIfPathExist(String) - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 
clearUpTo(long) - Method in class org.thales.punch.kafka.impl.OffsetTree
Clear all items up to the given value
close() - Method in interface org.thales.punch.kafka.api.IKafkaContinuousConsumer
Close this consumer
close() - Method in interface org.thales.punch.kafka.api.IPartition
Close this partition
close() - Method in class org.thales.punch.kafka.application.ApplicationExitControllerImpl
 
close() - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
 
close() - Method in class org.thales.punch.kafka.impl.MonitoredPartition
Closing means unregistering all our metrics.
close() - Method in class org.thales.punch.kafka.platform.KafkaAdminConsumer
 
close() - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 
COMMAND_V1 - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
The prefix header for start and stop commands.
COMMAND_V2 - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
large message are only handled by V2 start command.
commit() - Method in interface org.thales.punch.kafka.api.IKafkaContinuousConsumer
Commit all the offsets for all the partitions managed by your reader.
commit(String) - Method in interface org.thales.punch.kafka.api.IPartition
Commit the latest acknowledged offset for the given partition.
commit(long, String) - Method in interface org.thales.punch.kafka.api.IPartition
Commit an explicit offset for the given partition.
commit() - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
 
commit(String) - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
 
commit(long, String) - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
 
commit(String) - Method in class org.thales.punch.kafka.impl.StandardPartitionImpl
 
commit(long, String) - Method in class org.thales.punch.kafka.impl.StandardPartitionImpl
 
commitLatency - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
latency in milliseconds of kafka offset commit
committedOffsetGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
consumer - Variable in class org.thales.punch.kafka.impl.AbstractPartition
the consumer
contains(long) - Method in class org.thales.punch.kafka.impl.OffsetTree
Return true if this offset is currently in the set
currentDelayGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
currentTimestampGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 

D

date - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 

E

earliestOffset - Variable in class org.thales.punch.kafka.impl.AbstractPartition
 
earliestOffsetGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
entityName - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
entityType - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
entityUuid - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
exit(int) - Method in class org.thales.punch.kafka.application.ApplicationExitReporterImpl
 
exit(IBook, int) - Method in class org.thales.punch.kafka.application.BookExitReporterImpl
 
exitCode - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
ExitRequestImpl - Class in org.thales.punch.kafka.application
A simple pojo to keep track of exit requests
ExitRequestImpl(String, String, String, String, int) - Constructor for class org.thales.punch.kafka.application.ExitRequestImpl
 
ExitRequestImpl(ApplicationControlRecordPojo) - Constructor for class org.thales.punch.kafka.application.ExitRequestImpl
 

F

fail(long) - Method in interface org.thales.punch.kafka.api.IPartition
Optional operation, fail an offset.
fail(long) - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
 
fetchSize - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
size of messages in bytes
forApplication(String, String) - Method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
forBookStart(int) - Method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
forEntity(String, String, String) - Method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
forExit(int) - Method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
forReceiver(IRecordHandler<K, V>) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
forStart(int) - Method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
fromValue(byte[]) - Static method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 

G

getAdminProducer(String, JavaStoreSecurity) - Static method in class org.thales.punch.kafka.platform.KafkaAdminProducerUtil
Return a producer for admin purpose.
getApplicationName() - Method in class org.thales.punch.kafka.application.ExitRequestImpl
 
getApplicationUUID() - Method in class org.thales.punch.kafka.application.ExitRequestImpl
 
getAttachment() - Method in interface org.thales.punch.kafka.api.IPartition
 
getAttachment() - Method in class org.thales.punch.kafka.impl.AbstractPartition
 
getCommandRecordKey(String) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
 
getCompleteV2Record(String, byte[], Map<String, List<byte[]>>) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
This method receives the sequence of chunk from the same application start command, and aggregate them all.
getContinuousConsumerBuilder(String, String, String...) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
This is a light helper to create continuous consumers well-configured for the punch internal kafka admin and shiva protocol.
getDefaultVisitor(String, List<String>, List<String>) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
To start a shiva application, a zip archive is sent to each worker.
getEntityName() - Method in class org.thales.punch.kafka.application.ExitRequestImpl
 
getEntityUUID() - Method in class org.thales.punch.kafka.application.ExitRequestImpl
 
getExitCode() - Method in class org.thales.punch.kafka.application.ExitRequestImpl
 
getLargestOffsetFromFirstSequence() - Method in class org.thales.punch.kafka.impl.OffsetTree
getLargestOffsetFromFirstSequence(1 2 6 7) returns 2.
getPartitionNumber() - Method in interface org.thales.punch.kafka.api.IPartition
 
getPartitionNumber() - Method in class org.thales.punch.kafka.impl.AbstractPartition
 
getProducer(String, String) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
Get a simple Kafka producer.
getProducer(String, String, JavaStoreSecurity) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
Get a simple Kafka producer.
getTerminatedApplications(List<IApplication>, Duration) - Method in class org.thales.punch.kafka.application.ApplicationExitControllerImpl
 
getTopic() - Method in interface org.thales.punch.kafka.api.IPartition
 
getTopic() - Method in class org.thales.punch.kafka.impl.AbstractPartition
 
getV2CommandRecordKey(String, int, int) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
This one is used to send too big payloads.
getWorkerDeclarationMap(String, List<String>) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
Return a json document that represents the declaration of a new worker.

I

IKafkaContinuousConsumer - Interface in org.thales.punch.kafka.api
The IKafkaContinuousConsumer is your main interface to continuously consume kafka topics.
IKafkaSettingsMapConsumer - Interface in org.thales.punch.kafka.api
The IKafkaSettingsMapConsumer is your main interface to read the latest settings map record from a punch admin topic or assignement topic.
IPartition - Interface in org.thales.punch.kafka.api
This interface lets you receive, acknowledge your records, in a way to let you achieve at-least/exactly once semantics.
IRecordHandler<K,V> - Interface in org.thales.punch.kafka.api
This is your interface to receive Kafka records.
isEmpty() - Method in class org.thales.punch.kafka.impl.OffsetTree
 

K

KafkaAdminConstants - Class in org.thales.punch.kafka.platform
 
KafkaAdminConsumer - Class in org.thales.punch.kafka.platform
The punch admin uses Kafka topics in particular ways.
KafkaAdminConsumer(String, String, String, String, JavaStoreSecurity) - Constructor for class org.thales.punch.kafka.platform.KafkaAdminConsumer
Ctor.
KafkaAdminProducerUtil - Class in org.thales.punch.kafka.platform
This class groups the various values that are part of the Punch protocol implemented on top of Kafka.
KafkaConfigurationStoreImpl - Class in org.thales.punch.kafka.platform
This store is implemented onto a single compacted Kafka topic.
KafkaConfigurationStoreImpl(String, String, JavaStoreSecurity) - Constructor for class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 
KafkaConsumerImpl<K,V> - Class in org.thales.punch.kafka.impl
The IKafkaReader implementation.
KafkaConsumerImpl(Properties, String[], int, KafkaContinuousConsumerBuilder.START_OFFSET_STRATEGY, long, long, Long, boolean, JavaStoreSecurity) - Constructor for class org.thales.punch.kafka.impl.KafkaConsumerImpl
Ctor.
KafkaConsumerMetrics - Class in org.thales.punch.kafka.test
Quick main to test broker's metrics fetching
KafkaConsumerMetrics() - Constructor for class org.thales.punch.kafka.test.KafkaConsumerMetrics
 
KafkaContinuousConsumerBuilder<K,V> - Class in org.thales.punch.kafka.api
KafkaContinuousConsumerBuilder() - Constructor for class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
public ctor
KafkaContinuousConsumerBuilder.START_OFFSET_STRATEGY - Enum in org.thales.punch.kafka.api
One of "earliest", "last_committed", "latest", "from_offset" or "from_timestamp".
KafkaSecurityUtil - Class in org.thales.punch.kafka.impl
 
KafkaSecurityUtil() - Constructor for class org.thales.punch.kafka.impl.KafkaSecurityUtil
 
KafkaSettingsMapConsumerBuilder - Class in org.thales.punch.kafka.api
KafkaSettingsMapConsumerBuilder() - Constructor for class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 
KafkaShivaConstants - Class in org.thales.punch.kafka.platform
This class groups the various values that are part of the Punch protocol implemented on top of Kafka.
KafkaShivaUtil - Class in org.thales.punch.kafka.platform
This class groups the various values that are part of the Punch protocol implemented on top of Kafka used between the command line client or API, and the shiva daemon.

L

latestOffset - Variable in class org.thales.punch.kafka.impl.AbstractPartition
 
latestOffsetGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
logRcv(String, ConsumerRecord<String, byte[]>) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
 

M

main(String[]) - Static method in class org.thales.punch.kafka.test.KafkaConsumerMetrics
 
MAX_RECORD_LENGTH - Static variable in class org.thales.punch.kafka.platform.KafkaShivaUtil
Max default kafka record size is 1Mb.
messagesCommitBacklogGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
messagesFetchBacklogGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
messagesPersistedBacklogGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
messagesReplayableGauge - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
 
metricsContext - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
the metrics context in charge of periodically publishing our metrics with the adequate names and tags
MockPartition - Class in org.thales.punch.kafka.test
A mock partition.
MonitoredPartition - Class in org.thales.punch.kafka.impl
This class holds per partition metrics.
MonitoredPartition(IMetricContext, String, int, Long) - Constructor for class org.thales.punch.kafka.impl.MonitoredPartition
 
MONITORING_READER_GROUP_ID - Static variable in class org.thales.punch.kafka.platform.KafkaAdminConstants
 
msgFetchRate - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
rate (per second) of messages read from a partition

N

nextMessages(Duration) - Method in interface org.thales.punch.kafka.api.IKafkaContinuousConsumer
Fetch incoming messages, if any.
nextMessages(Duration) - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
 

O

offsetAckRate - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
offset acknowledgement rate
offsetFailRate - Variable in class org.thales.punch.kafka.impl.MonitoredPartition
offset acknowledgement rate
OffsetTree - Class in org.thales.punch.kafka.impl
An OffsetTree is a sorted set of longs to manage Kafka offset.
OffsetTree() - Constructor for class org.thales.punch.kafka.impl.OffsetTree
 
OffsetTreePartitionImpl<K,V> - Class in org.thales.punch.kafka.impl
Our IPartition implementation.
OffsetTreePartitionImpl(IMetricContext, String, int, KafkaConsumer<K, V>, long, Long, boolean) - Constructor for class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
constructor
onPartitionAssigned(IPartition, OffsetAndMetadata) - Method in interface org.thales.punch.kafka.api.IRecordHandler
Notification of an assigned partition.
onPartitionRevoked(IPartition) - Method in interface org.thales.punch.kafka.api.IRecordHandler
Notification of a revoked partition.
onReceive(IPartition, ConsumerRecord<K, V>) - Method in interface org.thales.punch.kafka.api.IRecordHandler
Be notified upon the arrival of a record.
onReceive(IPartition, ConsumerRecord<String, byte[]>) - Method in class org.thales.punch.kafka.application.ApplicationExitControllerImpl
 
onReceive(IRecordHandler<K, V>, ConsumerRecord<K, V>) - Method in class org.thales.punch.kafka.impl.AbstractPartition
 
onReceive(IRecordHandler<K, V>, ConsumerRecord<K, V>) - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
Transfer the record to the receiver and keep track of current offset.
onReceive(IRecordHandler<K, V>, ConsumerRecord<K, V>) - Method in class org.thales.punch.kafka.impl.StandardPartitionImpl
Transfer the record to the receiver.
onTick(IPartition, long) - Method in interface org.thales.punch.kafka.api.IRecordHandler
Be regularly called for each managed partition.
org.thales.punch.kafka.api - package org.thales.punch.kafka.api
 
org.thales.punch.kafka.application - package org.thales.punch.kafka.application
 
org.thales.punch.kafka.impl - package org.thales.punch.kafka.impl
 
org.thales.punch.kafka.platform - package org.thales.punch.kafka.platform
 
org.thales.punch.kafka.test - package org.thales.punch.kafka.test
 

P

partitionNumber - Variable in class org.thales.punch.kafka.impl.AbstractPartition
our partition number
PING_V1 - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
Leader send this message on the control topic periodically.
PONG_V1 - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
Worker send this message every time a leader sent its PING_V1 message.

R

readLatestBytes(Duration) - Method in class org.thales.punch.kafka.platform.KafkaAdminConsumer
 
readLatestSettingsMap(Duration) - Method in interface org.thales.punch.kafka.api.IKafkaSettingsMapConsumer
Read the latest json settings map from a topic.
readLatestSettingsMap(Duration) - Method in class org.thales.punch.kafka.platform.KafkaAdminConsumer
Read the latest map saved in the admin topic.
readMap(String) - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 
refresh() - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 
removeStartingFrom(long) - Method in class org.thales.punch.kafka.impl.OffsetTree
 
rewind(long) - Method in interface org.thales.punch.kafka.api.IPartition
Optional operation, rewind the offset to a past position.
rewind(long) - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
 
rmr(String) - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 

S

send(String, KafkaProducer<String, byte[]>, ProducerRecord<String, byte[]>) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
Send and trace a gossip message.
setAutoCommit() - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Start reading from the earliest offset.
setAutoCommitInterval(long) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Set the auto commit interval
setBootstrapServer(String) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setBootstrapServer(String) - Method in class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 
setClientId(String) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setClientId(String) - Method in class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 
setEarliestOffset(Long) - Method in class org.thales.punch.kafka.impl.AbstractPartition
 
setEarliestStartOffsetStrategy() - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Start reading from the earliest offset.
setFromDatetimeStartOffsetStrategy(String, String, boolean) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Start reading from a specific datetime.
setFromDatetimeStartOffsetStrategy(String, String) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setFromOffsetStartStrategy(long) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Start reading from an offset
setGroupId(String) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setGroupId(String) - Method in class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 
setLastCommittedStartOffsetStrategy() - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Use a last commit strategy.
setLatestOffset(Long) - Method in class org.thales.punch.kafka.impl.AbstractPartition
 
setLatestStartOffsetStrategy() - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Start reading from the latest offset.
setMetricContext(IMetricContext) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Associate a metricContext to the kafka reader.
setMetricContext(IMetricContext) - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
Provide a metric context to this consumer
setOffsetTree(boolean) - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
Request an offset tree t=strategy.
setOffsetTreeAckStrategy() - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Enable the ack and fail method of your IPartition handle to be handled using the underlyinh offset tree strategy.
setOffsetWatchDogTimeout(Long) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Set offset watchdog timeout.
setPartitionNumber(int) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Set a partition number if you want to consume only a given partition.
setProperties(Properties) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Set additional properties, typically some defined in the kafka consumer javadocs.
setProperty(String, Object) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Set additional property, typically some defined in the kafka consumer javadocs.
setReceiver(IRecordHandler<K, V>) - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
PSet the receiver to handle incoming records.
setSecurityStores(JavaStoreSecurity) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setSecurityStores(JavaStoreSecurity) - Method in class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 
setSecurityStores(Properties, JavaStoreSecurity) - Static method in class org.thales.punch.kafka.impl.KafkaSecurityUtil
 
setSmartFailureHandling(boolean) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
If set to true, after a failure already acked or pending records will not be reemitted.
setSmartFailureHandling(boolean) - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
Set the smart failure handling.
setTickInterval(long) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setTickInterval(long) - Method in class org.thales.punch.kafka.impl.KafkaConsumerImpl
Set the tick interval.
setTopic(String...) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
 
setTopic(List<String>) - Method in class org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder
Set the topics to be consumed by this consumer.
setTopic(String) - Method in class org.thales.punch.kafka.api.KafkaSettingsMapConsumerBuilder
 
SHIVA_LEADER_GROUP_ID - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
The group identifier used by all leaders.
SHIVA_WORKER_GROUP_ID_PREFIX - Static variable in class org.thales.punch.kafka.platform.KafkaShivaConstants
Workers have each their own group id so that they all read the same topics.
size() - Method in class org.thales.punch.kafka.impl.OffsetTree
 
stage - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
StandardPartitionImpl<K,V> - Class in org.thales.punch.kafka.impl
Our IPartition implementation when consumer work with a straigth commit strategy, not requesting the fancy offset tree mode.
StandardPartitionImpl(IMetricContext, String, int, KafkaConsumer<K, V>, long, Long) - Constructor for class org.thales.punch.kafka.impl.StandardPartitionImpl
constructor
start(String, String, String, String, int) - Method in class org.thales.punch.kafka.application.ApplicationStartReporterImpl
 
start(IBook) - Method in class org.thales.punch.kafka.application.BookActiveReporterImpl
 
startBlocking() - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 

T

toJsonString(ApplicationControlRecordPojo) - Static method in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 
topic - Variable in class org.thales.punch.kafka.impl.AbstractPartition
our topic
toString() - Method in class org.thales.punch.kafka.impl.OffsetTree
 
toString() - Method in class org.thales.punch.kafka.impl.OffsetTreePartitionImpl
 
toString() - Method in class org.thales.punch.kafka.impl.StandardPartitionImpl
 

V

valueOf(String) - Static method in enum org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder.START_OFFSET_STRATEGY
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.thales.punch.kafka.api.KafkaContinuousConsumerBuilder.START_OFFSET_STRATEGY
Returns an array containing the constants of this enum type, in the order they are declared.
version - Variable in class org.thales.punch.kafka.application.ApplicationControlRecordPojo
 

W

writeAdminMap(String, KafkaProducer<String, byte[]>, ISettingsMap) - Static method in class org.thales.punch.kafka.platform.KafkaShivaUtil
Write a settings map to the administration topics.
writeMap(ISettingsMap, String) - Method in class org.thales.punch.kafka.platform.KafkaConfigurationStoreImpl
 
A B C D E F G I K L M N O P R S T V W 
Skip navigation links

Copyright © 2014–2023. All rights reserved.