IN
- type of PubSubSink messages to writepublic class PubSubSink<IN> extends RichSinkFunction<IN> implements CheckpointedFunction
Modifier and Type | Class and Description |
---|---|
static interface |
PubSubSink.ProjectNameBuilder<IN>
Part of
PubSubSink.PubSubSinkBuilder to set required fields. |
static class |
PubSubSink.PubSubSinkBuilder<IN>
PubSubSinkBuilder to create a PubSubSink.
|
static class |
PubSubSink.SerializationSchemaBuilder
Part of
PubSubSink.PubSubSinkBuilder to set required fields. |
static interface |
PubSubSink.TopicNameBuilder<IN>
Part of
PubSubSink.PubSubSinkBuilder to set required fields. |
SinkFunction.Context<T>
Modifier and Type | Method and Description |
---|---|
void |
close()
Tear-down method for the user code.
|
void |
initializeState(FunctionInitializationContext context)
This method is called when the parallel function instance is created during distributed
execution.
|
void |
invoke(IN message,
SinkFunction.Context context)
Writes the given value to the sink.
|
static PubSubSink.SerializationSchemaBuilder |
newBuilder()
Create a builder for a new PubSubSink.
|
void |
open(Configuration configuration)
Initialization method for the function.
|
void |
snapshotState(FunctionSnapshotContext context)
This method is called when a snapshot for a checkpoint is requested.
|
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
invoke
public void open(Configuration configuration) throws Exception
RichFunction
The configuration object passed to the function can be used for configuration and initialization. The configuration contains all parameters that were configured on the function in the program composition.
public class MyFilter extends RichFilterFunction<String> {
private String searchString;
public void open(Configuration parameters) {
this.searchString = parameters.getString("foo");
}
public boolean filter(String value) {
return value.equals(searchString);
}
}
By default, this method does nothing.
open
in interface RichFunction
open
in class AbstractRichFunction
configuration
- The configuration containing the parameters attached to the contract.Exception
- Implementations may forward exceptions, which are caught by the runtime.
When the runtime catches an exception, it aborts the task and lets the fail-over logic
decide whether to retry the task execution.Configuration
public void close() throws Exception
RichFunction
This method can be used for clean up work.
close
in interface RichFunction
close
in class AbstractRichFunction
Exception
- Implementations may forward exceptions, which are caught by the runtime.
When the runtime catches an exception, it aborts the task and lets the fail-over logic
decide whether to retry the task execution.public void invoke(IN message, SinkFunction.Context context) throws Exception
SinkFunction
You have to override this method when implementing a SinkFunction
, this is a
default
method for backward compatibility with the old-style method only.
invoke
in interface SinkFunction<IN>
message
- The input record.context
- Additional context about the input record.Exception
- This method may throw exceptions. Throwing an exception will cause the
operation to fail and may trigger recovery.public static PubSubSink.SerializationSchemaBuilder newBuilder()
public void snapshotState(FunctionSnapshotContext context) throws Exception
CheckpointedFunction
FunctionInitializationContext
when the Function was initialized, or offered now by FunctionSnapshotContext
itself.snapshotState
in interface CheckpointedFunction
context
- the context for drawing a snapshot of the operatorException
- Thrown, if state could not be created ot restored.public void initializeState(FunctionInitializationContext context) throws Exception
CheckpointedFunction
initializeState
in interface CheckpointedFunction
context
- the context for initializing the operatorException
- Thrown, if state could not be created ot restored.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.