Uses of Interface
org.apache.flink.streaming.api.graph.StreamConfig.InputConfig
-
Packages that use StreamConfig.InputConfig Package Description org.apache.flink.streaming.api.graph org.apache.flink.streaming.runtime.io org.apache.flink.streaming.runtime.tasks -
-
Uses of StreamConfig.InputConfig in org.apache.flink.streaming.api.graph
Classes in org.apache.flink.streaming.api.graph that implement StreamConfig.InputConfig Modifier and Type Class Description static class
StreamConfig.NetworkInputConfig
A representation of a NetworkStreamConfig.InputConfig
.static class
StreamConfig.SourceInputConfig
A serialized representation of an input.Methods in org.apache.flink.streaming.api.graph that return StreamConfig.InputConfig Modifier and Type Method Description StreamConfig.InputConfig[]
StreamConfig. getInputs(ClassLoader cl)
Methods in org.apache.flink.streaming.api.graph with parameters of type StreamConfig.InputConfig Modifier and Type Method Description static boolean
StreamConfig. requiresSorting(StreamConfig.InputConfig inputConfig)
void
StreamConfig. setInputs(StreamConfig.InputConfig... inputs)
-
Uses of StreamConfig.InputConfig in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type StreamConfig.InputConfig Modifier and Type Method Description static StreamMultipleInputProcessor
StreamMultipleInputProcessorFactory. create(TaskInvokable ownerTask, CheckpointedInputGate[] checkpointedInputGates, StreamConfig.InputConfig[] configuredInputs, IOManager ioManager, MemoryManager memoryManager, 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, InflightDataRescalingDescriptor inflightDataRescalingDescriptor, Function<Integer,StreamPartitioner<?>> gatePartitioners, org.apache.flink.api.common.TaskInfo taskInfo, StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords)
-
Uses of StreamConfig.InputConfig in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type StreamConfig.InputConfig Modifier and Type Method Description protected void
MultipleInputStreamTask. createInputProcessor(List<IndexedInputGate>[] inputGates, StreamConfig.InputConfig[] inputs, WatermarkGauge[] inputWatermarkGauges, Function<Integer,StreamPartitioner<?>> gatePartitioners)
-