Class GlobalStateUpdateTask
- java.lang.Object
-
- org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
-
public class GlobalStateUpdateTask extends java.lang.Object
Updates the state for all Global State Stores.
-
-
Constructor Summary
Constructors Constructor Description GlobalStateUpdateTask(org.apache.kafka.common.utils.LogContext logContext, ProcessorTopology topology, InternalProcessorContext processorContext, GlobalStateManager stateMgr, DeserializationExceptionHandler deserializationExceptionHandler)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close(boolean wipeStateStore)
void
flushState()
java.util.Map<org.apache.kafka.common.TopicPartition,java.lang.Long>
initialize()
void
update(org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]> record)
-
-
-
Constructor Detail
-
GlobalStateUpdateTask
public GlobalStateUpdateTask(org.apache.kafka.common.utils.LogContext logContext, ProcessorTopology topology, InternalProcessorContext processorContext, GlobalStateManager stateMgr, DeserializationExceptionHandler deserializationExceptionHandler)
-
-
Method Detail
-
initialize
public java.util.Map<org.apache.kafka.common.TopicPartition,java.lang.Long> initialize()
- Throws:
java.lang.IllegalStateException
- If store gets registered after initialized is already finishedStreamsException
- If the store's change log does not contain the partition
-
update
public void update(org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]> record)
-
flushState
public void flushState()
-
close
public void close(boolean wipeStateStore) throws java.io.IOException
- Throws:
java.io.IOException
-
-