Package | Description |
---|---|
org.apache.flink.state.api | |
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.functions.windowing | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations on data streams.
|
org.apache.flink.streaming.runtime.operators.windowing.functions |
Class and Description |
---|
ProcessWindowFunction
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
WindowFunction
Base interface for functions that are evaluated over keyed (grouped) windows.
|
Class and Description |
---|
AllWindowFunction
Base interface for functions that are evaluated over non-keyed windows.
|
ProcessAllWindowFunction
Base abstract class for functions that are evaluated over non-keyed windows using a context for
retrieving extra information.
|
ProcessWindowFunction
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
WindowFunction
Base interface for functions that are evaluated over keyed (grouped) windows.
|
Class and Description |
---|
AllWindowFunction
Base interface for functions that are evaluated over non-keyed windows.
|
ProcessAllWindowFunction
Base abstract class for functions that are evaluated over non-keyed windows using a context for
retrieving extra information.
|
ProcessAllWindowFunction.Context
The context holding window metadata.
|
ProcessWindowFunction
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
ProcessWindowFunction.Context
The context holding window metadata.
|
WindowFunction
Base interface for functions that are evaluated over keyed (grouped) windows.
|
Class and Description |
---|
ProcessWindowFunction
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
WindowFunction
Base interface for functions that are evaluated over keyed (grouped) windows.
|
Class and Description |
---|
AllWindowFunction
Base interface for functions that are evaluated over non-keyed windows.
|
ProcessAllWindowFunction
Base abstract class for functions that are evaluated over non-keyed windows using a context for
retrieving extra information.
|
ProcessAllWindowFunction.Context
The context holding window metadata.
|
ProcessWindowFunction
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context
for retrieving extra information.
|
ProcessWindowFunction.Context
The context holding window metadata.
|
WindowFunction
Base interface for functions that are evaluated over keyed (grouped) windows.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.