Uses of Interface
org.apache.flink.runtime.state.KeyExtractorFunction
-
Packages that use KeyExtractorFunction Package Description org.apache.flink.runtime.state org.apache.flink.runtime.state.heap This package contains the classes for key/value state backends that store the state on the JVM heap as objects.org.apache.flink.streaming.api.operators -
-
Uses of KeyExtractorFunction in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state declared as KeyExtractorFunction Modifier and Type Field Description static KeyExtractorFunction<? extends Keyed<?>>KeyExtractorFunction. FOR_KEYED_OBJECTSMethods in org.apache.flink.runtime.state that return KeyExtractorFunction Modifier and Type Method Description static <T extends Keyed<?>>
KeyExtractorFunction<T>KeyExtractorFunction. forKeyedObjects()Constructors in org.apache.flink.runtime.state with parameters of type KeyExtractorFunction Constructor Description KeyGroupPartitioner(T[] partitioningSource, int numberOfElements, T[] partitioningDestination, KeyGroupRange keyGroupRange, int totalKeyGroups, KeyExtractorFunction<T> keyExtractorFunction, KeyGroupPartitioner.ElementWriterFunction<T> elementWriterFunction)Creates a newKeyGroupPartitioner. -
Uses of KeyExtractorFunction in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap with parameters of type KeyExtractorFunction Modifier and Type Method Description PQSKeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory. create(int keyGroupId, int numKeyGroups, KeyExtractorFunction<T> keyExtractorFunction, PriorityComparator<T> elementPriorityComparator)Creates a new queue for a given key-group partition.Constructors in org.apache.flink.runtime.state.heap with parameters of type KeyExtractorFunction Constructor Description HeapPriorityQueueSet(PriorityComparator<T> elementPriorityComparator, KeyExtractorFunction<T> keyExtractor, int minimumCapacity, KeyGroupRange keyGroupRange, int totalNumberOfKeyGroups)Creates an emptyHeapPriorityQueueSetwith the requested initial capacity.HeapPriorityQueueSnapshotRestoreWrapper(HeapPriorityQueueSet<T> priorityQueue, RegisteredPriorityQueueStateBackendMetaInfo<T> metaInfo, KeyExtractorFunction<T> keyExtractorFunction, KeyGroupRange localKeyGroupRange, int totalKeyGroups)KeyGroupPartitionedPriorityQueue(KeyExtractorFunction<T> keyExtractor, PriorityComparator<T> elementPriorityComparator, KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQ> orderedCacheFactory, KeyGroupRange keyGroupRange, int totalKeyGroups) -
Uses of KeyExtractorFunction in org.apache.flink.streaming.api.operators
Fields in org.apache.flink.streaming.api.operators declared as KeyExtractorFunction Modifier and Type Field Description static KeyExtractorFunction<InternalTimer<?,?>>InternalTimer. KEY_EXTRACTOR_FUNCTIONFunction to extract the key from aInternalTimer.
-