Skip navigation links
A B C D E F G I K L M N O P R S T U V W 

A

add(int, D) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given DataSet to this cache for the given ID.
add(int, U) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given UnsortedGrouping to this cache for the given ID.
add(int, S) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given SortedGrouping to this cache for the given ID.

B

BooleanSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
buffer - Variable in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
ByteSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
BytesSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 

C

close() - Method in class org.apache.flink.python.api.functions.PythonCoGroup
Closes this function.
close() - Method in class org.apache.flink.python.api.functions.PythonMapPartition
Closes this function.
close() - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
close() - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
close() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Closes this streamer.
close() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.python.api.functions.PythonCoGroup
Calls the external python function.
collectBuffer(Collector<OUT>, int) - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
Reads a buffer of the given size from the memory-mapped file, and collects all records contained.
count - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
createTuple(int) - Static method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
CustomTypeWrapper - Class in org.apache.flink.python.api.types
Container for serialized python objects, generally assumed to be custom objects.
CustomTypeWrapper(byte, byte[]) - Constructor for class org.apache.flink.python.api.types.CustomTypeWrapper
 
CustomTypeWrapperSerializer(CustomTypeWrapper) - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
 

D

DATA_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining where the memory-mapped files will be created.
DC_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining where the flink python library and user supplied files will be uploaded to before registering them with the Distributed Cache.
destroyProcess(Process) - Static method in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
DoubleSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
 

E

envID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
errorPrinter - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 

F

field - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
fieldDelimiter - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
finishPlanMode() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
FLINK_PYTHON_DC_ID - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON_PLAN_NAME - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FloatSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
 
frm - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
function - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 

G

getData() - Method in class org.apache.flink.python.api.types.CustomTypeWrapper
 
getDataSet(int) - Method in class org.apache.flink.python.api.util.SetCache
Returns the cached DataSet for the given ID.
getProducedType() - Method in class org.apache.flink.python.api.functions.PythonCoGroup
 
getProducedType() - Method in class org.apache.flink.python.api.functions.PythonMapPartition
 
getRecord() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
 
getRecord(boolean) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
 
getRecord() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
getRecord(boolean) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
getSerializer(IN) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
getSerializer(IN) - Static method in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
getSortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Returns the cached SortedGrouping for the given ID.
getType() - Method in class org.apache.flink.python.api.types.CustomTypeWrapper
 
getTypeInfoSize() - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
getTypeInfoSize() - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
getUnsortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Returns the cached UnsortedGrouping for the given ID.

I

identifier - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
IdentityGroupReduce<IN> - Class in org.apache.flink.python.api.functions.util
Utility function to group and sort data.
IdentityGroupReduce() - Constructor for class org.apache.flink.python.api.functions.util.IdentityGroupReduce
 
in - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
IntSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
 
isDataSet(int) - Method in class org.apache.flink.python.api.util.SetCache
Checks whether the cached set for the given ID is a DataSet.
isSortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Checks whether the cached set for the given ID is a SortedGrouping.
isUnsortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Checks whether the cached set for the given ID is an UnsortedGrouping.

K

KeyDiscarder<T> - Class in org.apache.flink.python.api.functions.util
Utility function to extract the value from a Key-Value Tuple.
KeyDiscarder() - Constructor for class org.apache.flink.python.api.functions.util.KeyDiscarder
 
keys - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
keys1 - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
keys2 - Variable in class org.apache.flink.python.api.PythonOperationInfo
 

L

lineDelimiter - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
LOG - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
LOG - Static variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
LongSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
 

M

main(String[]) - Static method in class org.apache.flink.python.api.PythonPlanBinder
Entry point for the execution of a python plan.
map(Tuple2<T, byte[]>) - Method in class org.apache.flink.python.api.functions.util.KeyDiscarder
 
map(IN) - Method in class org.apache.flink.python.api.functions.util.NestedKeyDiscarder
 
map(IN) - Method in class org.apache.flink.python.api.functions.util.SerializerMap
 
map(byte[]) - Method in class org.apache.flink.python.api.functions.util.StringDeserializerMap
 
map(byte[]) - Method in class org.apache.flink.python.api.functions.util.StringTupleDeserializerMap
 
mapPartition(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.python.api.functions.PythonMapPartition
 
MMAP_FILE_SIZE - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining the size of the memory-mapped files, in kb.
msg - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 

N

name - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
NestedKeyDiscarder<IN> - Class in org.apache.flink.python.api.functions.util
Utility function to extract values from 2 Key-Value Tuples after a DefaultJoin.
NestedKeyDiscarder() - Constructor for class org.apache.flink.python.api.functions.util.NestedKeyDiscarder
 
NullSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 

O

open(Configuration) - Method in class org.apache.flink.python.api.functions.PythonCoGroup
Opens this function.
open(Configuration) - Method in class org.apache.flink.python.api.functions.PythonMapPartition
Opens this function.
open(File) - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
open(File) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
open() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Starts the python script.
open(String, String) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
order - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
org.apache.flink.python.api - package org.apache.flink.python.api
 
org.apache.flink.python.api.functions - package org.apache.flink.python.api.functions
 
org.apache.flink.python.api.functions.util - package org.apache.flink.python.api.functions.util
 
org.apache.flink.python.api.streaming.data - package org.apache.flink.python.api.streaming.data
 
org.apache.flink.python.api.streaming.plan - package org.apache.flink.python.api.streaming.plan
 
org.apache.flink.python.api.streaming.util - package org.apache.flink.python.api.streaming.util
 
org.apache.flink.python.api.types - package org.apache.flink.python.api.types
 
org.apache.flink.python.api.util - package org.apache.flink.python.api.util
 
otherID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
out - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
outPrinter - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 

P

parallelism - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
parentID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
path - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
PLAN_ARGUMENTS_KEY - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
PLAN_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining where temporary plan-related files are stored on the client.
PLANBINDER_CONFIG_BCVAR_COUNT - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
PLANBINDER_CONFIG_BCVAR_NAME_PREFIX - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
port - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
preparePlanMode() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
PYTHON_BINARY_PATH - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining the path to the python binary to use.
PythonCoGroup<IN1,IN2,OUT> - Class in org.apache.flink.python.api.functions
CoGroupFunction that uses a python script.
PythonCoGroup(Configuration, int, int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonCoGroup
 
PythonDualInputSender<IN1,IN2> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonSender for operations with two input streams.
PythonDualInputSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonDualInputSender
 
PythonDualInputStreamer<IN1,IN2,OUT> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonStreamer for operations with two input stream.
PythonDualInputStreamer(AbstractRichFunction, Configuration, int, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonDualInputStreamer
 
PythonMapPartition<IN,OUT> - Class in org.apache.flink.python.api.functions
Multi-purpose class, usable by all operations using a python script with one input source and possibly differing in-/output types.
PythonMapPartition(Configuration, int, int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonMapPartition
 
PythonOperationInfo - Class in org.apache.flink.python.api
Generic container for all information required to an operation to the DataSet API.
PythonOperationInfo(PythonPlanStreamer, int) - Constructor for class org.apache.flink.python.api.PythonOperationInfo
 
PythonOptions - Class in org.apache.flink.python.api
Configuration options for the Python API.
PythonPlanBinder - Class in org.apache.flink.python.api
This class allows the execution of a Flink plan written in python.
PythonPlanBinder(Configuration) - Constructor for class org.apache.flink.python.api.PythonPlanBinder
 
PythonPlanBinder.Operation - Enum in org.apache.flink.python.api
This enum contains the identifiers for all supported DataSet operations.
PythonPlanReceiver - Class in org.apache.flink.python.api.streaming.plan
Instances of this class can be used to receive data from the plan process.
PythonPlanReceiver(InputStream) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
 
PythonPlanSender - Class in org.apache.flink.python.api.streaming.plan
Instances of this class can be used to send data to the plan process.
PythonPlanSender(OutputStream) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanSender
 
PythonPlanStreamer - Class in org.apache.flink.python.api.streaming.plan
Generic class to exchange data during the plan phase.
PythonPlanStreamer(Configuration) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
PythonReceiver<OUT> - Class in org.apache.flink.python.api.streaming.data
This class is used to read data from memory-mapped files.
PythonReceiver(Configuration, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonReceiver
 
PythonSender - Class in org.apache.flink.python.api.streaming.data
General-purpose class to write data to memory-mapped files.
PythonSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender
 
PythonSender.Serializer<T> - Class in org.apache.flink.python.api.streaming.data
Interface for all serializers used by PythonSender classes to write container objects.
PythonSingleInputSender<IN> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonSender for operations with one input stream.
PythonSingleInputSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSingleInputSender
 
PythonSingleInputStreamer<IN,OUT> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonStreamer for operations with one input stream.
PythonSingleInputStreamer(AbstractRichFunction, Configuration, int, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSingleInputStreamer
 
PythonStreamer<S extends PythonSender,OUT> - Class in org.apache.flink.python.api.streaming.data
This streamer is used by functions to send/receive data to/from an external python process.
PythonStreamer(AbstractRichFunction, Configuration, int, int, boolean, S) - Constructor for class org.apache.flink.python.api.streaming.data.PythonStreamer
 

R

receiver - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
receiver - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
reduce(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.python.api.functions.util.IdentityGroupReduce
 
reset() - Method in class org.apache.flink.python.api.util.SetCache
Resets this SetCache, removing any cached sets.
run() - Method in class org.apache.flink.python.api.streaming.util.StreamPrinter
 

S

sendBroadCastVariables(Configuration) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Sends all broadcast-variables encoded in the configuration to the external process.
sendBuffer(SingleElementPushBackIterator<IN>, PythonSender.Serializer<IN>) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendBuffer(SingleElementPushBackIterator<IN>) - Method in class org.apache.flink.python.api.streaming.data.PythonSingleInputSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendBuffer1(SingleElementPushBackIterator<IN1>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendBuffer2(SingleElementPushBackIterator<IN2>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputSender
Extracts records from an iterator and writes them to the memory-mapped file.
sender - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
sender - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
sendReadConfirmation() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
sendRecord(Object) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanSender
 
sendRecord(Object) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
sendWriteNotification(int, boolean) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SerializationUtils - Class in org.apache.flink.python.api.streaming.util
Utility class containing serializers for all supported types.
SerializationUtils() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils
 
SerializationUtils.BooleanSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for booleans.
SerializationUtils.ByteSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for bytes.
SerializationUtils.BytesSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for byte arrays.
SerializationUtils.CustomTypeWrapperSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for CustomTypeWrappers.
SerializationUtils.DoubleSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for doubles.
SerializationUtils.FloatSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for floats.
SerializationUtils.IntSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for ints.
SerializationUtils.LongSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for longs.
SerializationUtils.NullSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for null.
SerializationUtils.Serializer<IN> - Class in org.apache.flink.python.api.streaming.util
Super class for all serializers used to serialize data.
SerializationUtils.StringSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for strings.
SerializationUtils.TupleSerializer - Class in org.apache.flink.python.api.streaming.util
A serializer for tuples.
serialize(T) - Method in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
Serializes the given value into a ByteBuffer.
serialize(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
serializeInternal(T) - Method in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
Serializer() - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
Serializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
SerializerMap<IN> - Class in org.apache.flink.python.api.functions.util
Utility function to serialize values, usually directly from data sources.
SerializerMap() - Constructor for class org.apache.flink.python.api.functions.util.SerializerMap
 
serializeWithoutTypeInfo(Boolean) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
serializeWithoutTypeInfo(Byte) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
serializeWithoutTypeInfo(byte[]) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 
serializeWithoutTypeInfo(CustomTypeWrapper) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
 
serializeWithoutTypeInfo(Double) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
 
serializeWithoutTypeInfo(Float) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
 
serializeWithoutTypeInfo(Integer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
 
serializeWithoutTypeInfo(Long) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
 
serializeWithoutTypeInfo(Object) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 
serializeWithoutTypeInfo(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
serializeWithoutTypeInfo(String) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
 
serializeWithoutTypeInfo(Tuple) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
server - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SetCache - Class in org.apache.flink.python.api.util
A container holding DataSets, sorted andunsorted groupings.
SetCache() - Constructor for class org.apache.flink.python.api.util.SetCache
 
setID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
SIGNAL_BUFFER_REQUEST - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_BUFFER_REQUEST_G0 - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_BUFFER_REQUEST_G1 - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_ERROR - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_FINISHED - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_LAST - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
socket - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
streamBufferWithGroups(Iterator<IN1>, Iterator<IN2>, Collector<OUT>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputStreamer
Sends all values contained in both iterators to the external process and collects all results.
streamBufferWithoutGroups(Iterator<IN>, Collector<OUT>) - Method in class org.apache.flink.python.api.streaming.data.PythonSingleInputStreamer
Sends all values contained in the iterator to the external process and collects all results.
StreamPrinter - Class in org.apache.flink.python.api.streaming.util
Simple utility class to print all contents of an inputstream to stdout.
StreamPrinter(InputStream) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
 
StreamPrinter(InputStream, AtomicReference<String>) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
 
StringDeserializerMap - Class in org.apache.flink.python.api.functions.util
Utility function to deserialize strings, used for non-CSV sinks.
StringDeserializerMap() - Constructor for class org.apache.flink.python.api.functions.util.StringDeserializerMap
 
StringSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
 
StringTupleDeserializerMap - Class in org.apache.flink.python.api.functions.util
Utility function to deserialize strings, used for CSV sinks.
StringTupleDeserializerMap() - Constructor for class org.apache.flink.python.api.functions.util.StringTupleDeserializerMap
 

T

to - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
toError - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
toString() - Method in class org.apache.flink.python.api.PythonOperationInfo
 
TupleSerializer(Tuple) - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
TYPE_ARRAY - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
 
TYPE_BOOLEAN - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_BYTE - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_BYTES - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_DOUBLE - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_FLOAT - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_INTEGER - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_KEY_VALUE - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
 
TYPE_LONG - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_NULL - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_STRING - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_VALUE_VALUE - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
 
types - Variable in class org.apache.flink.python.api.PythonOperationInfo
 

U

usesUDF - Variable in class org.apache.flink.python.api.PythonOperationInfo
 

V

valueOf(String) - Static method in enum org.apache.flink.python.api.PythonPlanBinder.Operation
Returns the enum constant of this type with the specified name.
values - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
values() - Static method in enum org.apache.flink.python.api.PythonPlanBinder.Operation
Returns an array containing the constants of this enum type, in the order they are declared.

W

writeMode - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
A B C D E F G I K L M N O P R S T U V W 
Skip navigation links

Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.