Modifier and Type | Interface and Description |
---|---|
interface |
IterationRuntimeContext
A specialization of the
RuntimeContext available in iterative computations of the
DataSet API. |
Modifier and Type | Method and Description |
---|---|
RuntimeContext |
AbstractRichFunction.getRuntimeContext() |
RuntimeContext |
RichFunction.getRuntimeContext()
Gets the context that contains information about the UDF's runtime, such as the
parallelism of the function, the subtask index of the function, or the name of
the of the task that executes the function.
|
Modifier and Type | Method and Description |
---|---|
void |
AbstractRichFunction.setRuntimeContext(RuntimeContext t) |
void |
RichFunction.setRuntimeContext(RuntimeContext t)
Sets the function's runtime context.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRuntimeUDFContext
A standalone implementation of the
RuntimeContext , created by runtime UDF operators. |
class |
RuntimeUDFContext
A standalone implementation of the
RuntimeContext , created by runtime UDF operators. |
Modifier and Type | Method and Description |
---|---|
static RuntimeContext |
FunctionUtils.getFunctionRuntimeContext(Function function,
RuntimeContext defaultContext) |
Modifier and Type | Method and Description |
---|---|
static RuntimeContext |
FunctionUtils.getFunctionRuntimeContext(Function function,
RuntimeContext defaultContext) |
static void |
FunctionUtils.setFunctionRuntimeContext(Function function,
RuntimeContext context) |
Modifier and Type | Method and Description |
---|---|
RuntimeContext |
ReplicatingInputFormat.getRuntimeContext() |
RuntimeContext |
RichInputFormat.getRuntimeContext() |
RuntimeContext |
RichOutputFormat.getRuntimeContext() |
Modifier and Type | Method and Description |
---|---|
void |
ReplicatingInputFormat.setRuntimeContext(RuntimeContext context) |
void |
RichInputFormat.setRuntimeContext(RuntimeContext t) |
void |
RichOutputFormat.setRuntimeContext(RuntimeContext t) |
Modifier and Type | Method and Description |
---|---|
void |
FlinkConnectorRateLimiter.open(RuntimeContext runtimeContext)
A method that can be used to create and configure a ratelimiter
based on the runtimeContext.
|
void |
GuavaFlinkConnectorRateLimiter.open(RuntimeContext runtimeContext)
Creates a rate limiter with the runtime context provided.
|
Modifier and Type | Method and Description |
---|---|
protected void |
GenericDataSinkBase.executeOnCollections(List<IN> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected abstract List<OUT> |
SingleInputOperator.executeOnCollections(List<IN> inputData,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected abstract List<OUT> |
DualInputOperator.executeOnCollections(List<IN1> inputData1,
List<IN2> inputData2,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<T> |
Union.executeOnCollections(List<T> inputData1,
List<T> inputData2,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<OUT> |
GenericDataSourceBase.executeOnCollections(RuntimeContext ctx,
ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
protected List<OUT> |
MapPartitionOperatorBase.executeOnCollections(List<IN> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<OUT> |
GroupReduceOperatorBase.executeOnCollections(List<IN> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<OUT> |
GroupCombineOperatorBase.executeOnCollections(List<IN> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<IN> |
SortPartitionOperatorBase.executeOnCollections(List<IN> inputData,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<OUT> |
MapOperatorBase.executeOnCollections(List<IN> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<OUT> |
FlatMapOperatorBase.executeOnCollections(List<IN> input,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<IN> |
PartitionOperatorBase.executeOnCollections(List<IN> inputData,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<OUT> |
OuterJoinOperatorBase.executeOnCollections(List<IN1> leftInput,
List<IN2> rightInput,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<OUT> |
CrossOperatorBase.executeOnCollections(List<IN1> inputData1,
List<IN2> inputData2,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<OUT> |
CoGroupRawOperatorBase.executeOnCollections(List<IN1> input1,
List<IN2> input2,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<OUT> |
CoGroupOperatorBase.executeOnCollections(List<IN1> input1,
List<IN2> input2,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<OUT> |
InnerJoinOperatorBase.executeOnCollections(List<IN1> inputData1,
List<IN2> inputData2,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<ST> |
DeltaIterationBase.executeOnCollections(List<ST> inputData1,
List<WT> inputData2,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<T> |
ReduceOperatorBase.executeOnCollections(List<T> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
protected List<T> |
BulkIterationBase.executeOnCollections(List<T> inputData,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<T> |
FilterOperatorBase.executeOnCollections(List<T> inputData,
RuntimeContext ctx,
ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
void |
WrappingFunction.setRuntimeContext(RuntimeContext t) |
Modifier and Type | Method and Description |
---|---|
void |
NFA.open(RuntimeContext cepRuntimeContext,
Configuration conf)
Initialization method for the NFA.
|
Modifier and Type | Method and Description |
---|---|
RuntimeContext |
RichIterativeCondition.getRuntimeContext() |
Modifier and Type | Method and Description |
---|---|
void |
RichCompositeIterativeCondition.setRuntimeContext(RuntimeContext t) |
void |
RichIterativeCondition.setRuntimeContext(RuntimeContext runtimeContext) |
Modifier and Type | Method and Description |
---|---|
protected List<OUT> |
NoOpBinaryUdfOp.executeOnCollections(List<OUT> inputData1,
List<OUT> inputData2,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
protected List<OUT> |
NoOpUnaryUdfOp.executeOnCollections(List<OUT> inputData,
RuntimeContext runtimeContext,
ExecutionConfig executionConfig) |
Modifier and Type | Method and Description |
---|---|
protected RuntimeContext |
ChainedDriver.getUdfRuntimeContext() |
Modifier and Type | Class and Description |
---|---|
class |
DistributedRuntimeUDFContext
A standalone implementation of the
RuntimeContext , created by runtime UDF operators. |
Modifier and Type | Method and Description |
---|---|
void |
RichAsyncFunction.setRuntimeContext(RuntimeContext runtimeContext) |
Modifier and Type | Method and Description |
---|---|
void |
OutputFormatSinkFunction.setRuntimeContext(RuntimeContext context)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
FoldApplyProcessWindowFunction.setRuntimeContext(RuntimeContext t)
Deprecated.
|
void |
FoldApplyProcessAllWindowFunction.setRuntimeContext(RuntimeContext t)
Deprecated.
|
void |
ReduceApplyProcessWindowFunction.setRuntimeContext(RuntimeContext t) |
void |
ReduceApplyProcessAllWindowFunction.setRuntimeContext(RuntimeContext t) |
Modifier and Type | Class and Description |
---|---|
class |
StreamingRuntimeContext
Implementation of the
RuntimeContext ,
for streaming operators. |
Modifier and Type | Method and Description |
---|---|
org.elasticsearch.action.index.IndexRequest |
IndexRequestBuilder.createIndexRequest(T element,
RuntimeContext ctx)
Deprecated.
Creates an
IndexRequest from an element. |
void |
ElasticsearchSinkFunction.process(T element,
RuntimeContext ctx,
RequestIndexer indexer)
Process the incoming element to produce multiple
ActionsRequests . |
void |
ElasticsearchUpsertTableSinkBase.ElasticsearchUpsertSinkFunction.process(Tuple2<Boolean,Row> element,
RuntimeContext ctx,
RequestIndexer indexer) |
Modifier and Type | Method and Description |
---|---|
void |
ElasticsearchSinkFunction.process(T element,
RuntimeContext ctx,
RequestIndexer indexer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
NiFiDataPacket |
NiFiDataPacketBuilder.createNiFiDataPacket(T t,
RuntimeContext ctx) |
Modifier and Type | Method and Description |
---|---|
static <X> X |
InterpreterUtils.deserializeFunction(RuntimeContext context,
byte[] serFun)
Deserialize the given python function.
|
Modifier and Type | Method and Description |
---|---|
RuntimeContext |
InternalIterableProcessAllWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalAggregateProcessWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalIterableProcessWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalAggregateProcessAllWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalSingleValueProcessAllWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalSingleValueWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalSingleValueAllWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalSingleValueProcessWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalIterableWindowFunction.getRuntimeContext() |
RuntimeContext |
InternalIterableAllWindowFunction.getRuntimeContext() |
Constructor and Description |
---|
FunctionContext(RuntimeContext context)
Wraps the underlying
RuntimeContext . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.