@Deprecated @PublicEvolving public class CollectionInputFormat<T> extends org.apache.flink.api.common.io.GenericInputFormat<T> implements org.apache.flink.api.common.io.NonParallelInput
Constructor and Description |
---|
CollectionInputFormat(Collection<T> dataSet,
org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static <X> void |
checkCollection(Collection<X> elements,
Class<X> viewedAs)
Deprecated.
|
T |
nextRecord(T record)
Deprecated.
|
void |
open(org.apache.flink.core.io.GenericInputSplit split)
Deprecated.
|
boolean |
reachedEnd()
Deprecated.
|
String |
toString()
Deprecated.
|
close, configure, createInputSplits, getInputSplitAssigner, getStatistics
public CollectionInputFormat(Collection<T> dataSet, org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer)
public boolean reachedEnd() throws IOException
reachedEnd
in interface org.apache.flink.api.common.io.InputFormat<T,org.apache.flink.core.io.GenericInputSplit>
IOException
public void open(org.apache.flink.core.io.GenericInputSplit split) throws IOException
open
in interface org.apache.flink.api.common.io.InputFormat<T,org.apache.flink.core.io.GenericInputSplit>
open
in class org.apache.flink.api.common.io.GenericInputFormat<T>
IOException
public T nextRecord(T record) throws IOException
nextRecord
in interface org.apache.flink.api.common.io.InputFormat<T,org.apache.flink.core.io.GenericInputSplit>
IOException
public static <X> void checkCollection(Collection<X> elements, Class<X> viewedAs)
Copyright © 2014–2025 The Apache Software Foundation. All rights reserved.