Class NonChainedOutput

  • All Implemented Interfaces:
    Serializable

    @Internal
    public class NonChainedOutput
    extends Object
    implements Serializable
    Used by operator chain and represents a non-chained output of the corresponding stream operator.
    See Also:
    Serialized Form
    • Constructor Detail

      • NonChainedOutput

        public NonChainedOutput​(boolean supportsUnalignedCheckpoints,
                                int sourceNodeId,
                                int consumerParallelism,
                                int consumerMaxParallelism,
                                long bufferTimeout,
                                boolean isPersistentDataSet,
                                IntermediateDataSetID dataSetId,
                                org.apache.flink.util.OutputTag<?> outputTag,
                                StreamPartitioner<?> partitioner,
                                ResultPartitionType partitionType)
    • Method Detail

      • supportsUnalignedCheckpoints

        public boolean supportsUnalignedCheckpoints()
      • getSourceNodeId

        public int getSourceNodeId()
      • getConsumerParallelism

        public int getConsumerParallelism()
      • getConsumerMaxParallelism

        public int getConsumerMaxParallelism()
      • getBufferTimeout

        public long getBufferTimeout()
      • getOutputTag

        public org.apache.flink.util.OutputTag<?> getOutputTag()
      • hashCode

        public int hashCode()
        Overrides:
        hashCode in class Object