public final class UnboundedFeedbackLogger<T> extends java.lang.Object implements FeedbackLogger<T>
Constructor and Description |
---|
UnboundedFeedbackLogger(java.util.function.Supplier<org.apache.flink.statefun.flink.core.logger.KeyGroupStream<T>> supplier,
java.util.function.ToIntFunction<T> keyGroupAssigner,
CheckpointedStreamOperations ops,
org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer) |
Modifier and Type | Method and Description |
---|---|
void |
append(T message)
Append a message to the currently logging logger.
|
void |
close() |
void |
commit()
Commit the currently logging logger.
|
void |
replyLoggedEnvelops(java.io.InputStream rawKeyedStateInputs,
FeedbackConsumer<T> consumer) |
void |
startLogging(java.io.OutputStream keyedStateCheckpointOutputStream)
Start logging messages into the supplied output stream.
|
public UnboundedFeedbackLogger(java.util.function.Supplier<org.apache.flink.statefun.flink.core.logger.KeyGroupStream<T>> supplier, java.util.function.ToIntFunction<T> keyGroupAssigner, CheckpointedStreamOperations ops, org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer)
public void startLogging(java.io.OutputStream keyedStateCheckpointOutputStream)
FeedbackLogger
startLogging
in interface FeedbackLogger<T>
public void append(T message)
FeedbackLogger
append
in interface FeedbackLogger<T>
public void commit()
FeedbackLogger
commit
in interface FeedbackLogger<T>
public void replyLoggedEnvelops(java.io.InputStream rawKeyedStateInputs, FeedbackConsumer<T> consumer) throws java.lang.Exception
java.lang.Exception
public void close()
close
in interface java.lang.AutoCloseable
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.