Package | Description |
---|---|
org.apache.flink.runtime.checkpoint.channel | |
org.apache.flink.runtime.io.network.partition | |
org.apache.flink.runtime.io.network.partition.consumer | |
org.apache.flink.runtime.taskmanager | |
org.apache.flink.streaming.api.operators.sort | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.io.recovery | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Class and Description |
---|---|
static class |
ChannelStateWriter.NoOpChannelStateWriter
No-op implementation of
ChannelStateWriter . |
class |
ChannelStateWriterImpl
ChannelStateWriter implemented using CheckpointStateOutputStreams . |
Modifier and Type | Field and Description |
---|---|
static ChannelStateWriter |
ChannelStateWriter.NO_OP |
Modifier and Type | Method and Description |
---|---|
void |
ChannelStateHolder.setChannelStateWriter(ChannelStateWriter channelStateWriter)
Injects the
ChannelStateWriter . |
void |
PipelinedResultPartition.setChannelStateWriter(ChannelStateWriter channelStateWriter) |
void |
PipelinedSubpartition.setChannelStateWriter(ChannelStateWriter channelStateWriter) |
Modifier and Type | Field and Description |
---|---|
protected ChannelStateWriter |
RecoveredInputChannel.channelStateWriter |
Modifier and Type | Method and Description |
---|---|
void |
InputGate.setChannelStateWriter(ChannelStateWriter channelStateWriter) |
void |
RecoveredInputChannel.setChannelStateWriter(ChannelStateWriter channelStateWriter) |
Constructor and Description |
---|
LocalInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
int consumedSubpartitionIndex,
ResultPartitionManager partitionManager,
TaskEventPublisher taskEventPublisher,
int initialBackoff,
int maxBackoff,
Counter numBytesIn,
Counter numBuffersIn,
ChannelStateWriter stateWriter) |
RemoteInputChannel(SingleInputGate inputGate,
int channelIndex,
ResultPartitionID partitionId,
int consumedSubpartitionIndex,
ConnectionID connectionId,
ConnectionManager connectionManager,
int initialBackOff,
int maxBackoff,
int networkBuffersPerChannel,
Counter numBytesIn,
Counter numBuffersIn,
ChannelStateWriter stateWriter) |
Modifier and Type | Method and Description |
---|---|
void |
InputGateWithMetrics.setChannelStateWriter(ChannelStateWriter channelStateWriter) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
MultiInputSortingDataInput.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
CompletableFuture<Void> |
SortingDataInput.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
StreamTaskInput.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId)
Prepares to spill the in-flight input buffers as checkpoint snapshot.
|
CompletableFuture<Void> |
StreamOneInputProcessor.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
CompletableFuture<Void> |
StreamTaskNetworkInput.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
CompletableFuture<Void> |
StreamTaskSourceInput.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
CompletableFuture<Void> |
StreamInputProcessor.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
CompletableFuture<Void> |
StreamMultipleInputProcessor.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
RescalingStreamTaskNetworkInput.prepareSnapshot(ChannelStateWriter channelStateWriter,
long checkpointId) |
Modifier and Type | Method and Description |
---|---|
ChannelStateWriter |
SubtaskCheckpointCoordinator.getChannelStateWriter() |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.