Package | Description |
---|---|
org.apache.flink.streaming.api.graph | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Class and Description |
---|---|
static class |
StreamConfig.NetworkInputConfig
A representation of a Network
StreamConfig.InputConfig . |
static class |
StreamConfig.SourceInputConfig
A serialized representation of an input.
|
Modifier and Type | Method and Description |
---|---|
StreamConfig.InputConfig[] |
StreamConfig.getInputs(ClassLoader cl) |
Modifier and Type | Method and Description |
---|---|
static boolean |
StreamConfig.requiresSorting(StreamConfig.InputConfig inputConfig) |
void |
StreamConfig.setInputs(StreamConfig.InputConfig... inputs) |
Modifier and Type | Method and Description |
---|---|
static StreamMultipleInputProcessor |
StreamMultipleInputProcessorFactory.create(org.apache.flink.runtime.jobgraph.tasks.TaskInvokable ownerTask,
CheckpointedInputGate[] checkpointedInputGates,
StreamConfig.InputConfig[] configuredInputs,
org.apache.flink.runtime.io.disk.iomanager.IOManager ioManager,
org.apache.flink.runtime.memory.MemoryManager memoryManager,
org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup ioMetricGroup,
org.apache.flink.metrics.Counter mainOperatorRecordsIn,
MultipleInputStreamOperator<?> mainOperator,
WatermarkGauge[] inputWatermarkGauges,
StreamConfig streamConfig,
org.apache.flink.configuration.Configuration taskManagerConfig,
org.apache.flink.configuration.Configuration jobConfig,
org.apache.flink.api.common.ExecutionConfig executionConfig,
ClassLoader userClassloader,
OperatorChain<?,?> operatorChain,
org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor inflightDataRescalingDescriptor,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners,
org.apache.flink.api.common.TaskInfo taskInfo,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) |
Modifier and Type | Method and Description |
---|---|
protected void |
MultipleInputStreamTask.createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate>[] inputGates,
StreamConfig.InputConfig[] inputs,
WatermarkGauge[] inputWatermarkGauges,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.