org.apache.pulsar.functions.api.Context Maven / Gradle / Ivy
/**
* Licensed to the Apache Software Foundation (ASF) under one
* or more contributor license agreements. See the NOTICE file
* distributed with this work for additional information
* regarding copyright ownership. The ASF licenses this file
* to you under the Apache License, Version 2.0 (the
* "License"); you may not use this file except in compliance
* with the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing,
* software distributed under the License is distributed on an
* "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
* KIND, either express or implied. See the License for the
* specific language governing permissions and limitations
* under the License.
*/
package org.apache.pulsar.functions.api;
import java.nio.ByteBuffer;
import java.util.Collection;
import java.util.Map;
import java.util.Optional;
import java.util.concurrent.CompletableFuture;
import org.apache.pulsar.client.admin.PulsarAdmin;
import org.apache.pulsar.client.api.ConsumerBuilder;
import org.apache.pulsar.client.api.PulsarClientException;
import org.apache.pulsar.client.api.Schema;
import org.apache.pulsar.client.api.TypedMessageBuilder;
import org.apache.pulsar.common.classification.InterfaceAudience;
import org.apache.pulsar.common.classification.InterfaceStability;
import org.slf4j.Logger;
/**
* Context provides contextual information to the executing function.
* Features like which message id we are handling, whats the topic name of the
* message, what are our operating constraints, etc can be accessed by the
* executing function
*/
@InterfaceAudience.Public
@InterfaceStability.Stable
public interface Context {
/**
* Access the record associated with the current input value.
*
* @return
*/
Record> getCurrentRecord();
/**
* Get a list of all input topics.
*
* @return a list of all input topics
*/
Collection getInputTopics();
/**
* Get the output topic of the function.
*
* @return output topic name
*/
String getOutputTopic();
/**
* Get output schema builtin type or custom class name.
*
* @return output schema builtin type or custom class name
*/
String getOutputSchemaType();
/**
* The tenant this function belongs to.
*
* @return the tenant this function belongs to
*/
String getTenant();
/**
* The namespace this function belongs to.
*
* @return the namespace this function belongs to
*/
String getNamespace();
/**
* The name of the function that we are executing.
*
* @return The Function name
*/
String getFunctionName();
/**
* The id of the function that we are executing
*
* @return The function id
*/
String getFunctionId();
/**
* The id of the instance that invokes this function.
*
* @return the instance id
*/
int getInstanceId();
/**
* Get the number of instances that invoke this function.
*
* @return the number of instances that invoke this function.
*/
int getNumInstances();
/**
* The version of the function that we are executing.
*
* @return The version id
*/
String getFunctionVersion();
/**
* The logger object that can be used to log in a function.
*
* @return the logger object
*/
Logger getLogger();
/**
* Get the state store with the provided store name in the function tenant & namespace.
*
* @param name the state store name
* @param the type of interface of the store to return
* @return the state store instance.
*
* @throws ClassCastException if the return type isn't a type
* or interface of the actual returned store.
*/
S getStateStore(String name);
/**
* Get the state store with the provided store name.
*
* @param tenant the state tenant name
* @param ns the state namespace name
* @param name the state store name
* @param the type of interface of the store to return
* @return the state store instance.
*
* @throws ClassCastException if the return type isn't a type
* or interface of the actual returned store.
*/
S getStateStore(String tenant, String ns, String name);
/**
* Increment the builtin distributed counter referred by key.
*
* @param key The name of the key
* @param amount The amount to be incremented
*/
void incrCounter(String key, long amount);
/**
* Increment the builtin distributed counter referred by key
* but dont wait for the completion of the increment operation
*
* @param key The name of the key
* @param amount The amount to be incremented
*/
CompletableFuture incrCounterAsync(String key, long amount);
/**
* Retrieve the counter value for the key.
*
* @param key name of the key
* @return the amount of the counter value for this key
*/
long getCounter(String key);
/**
* Retrieve the counter value for the key, but don't wait
* for the operation to be completed
*
* @param key name of the key
* @return the amount of the counter value for this key
*/
CompletableFuture getCounterAsync(String key);
/**
* Update the state value for the key.
*
* @param key name of the key
* @param value state value of the key
*/
void putState(String key, ByteBuffer value);
/**
* Update the state value for the key, but don't wait for the operation to be completed
*
* @param key name of the key
* @param value state value of the key
*/
CompletableFuture putStateAsync(String key, ByteBuffer value);
/**
* Delete the state value for the key.
*
* @param key name of the key
*/
void deleteState(String key);
/**
* Delete the state value for the key, but don't wait for the operation to be completed
*
* @param key name of the key
*/
CompletableFuture deleteStateAsync(String key);
/**
* Retrieve the state value for the key.
*
* @param key name of the key
* @return the state value for the key.
*/
ByteBuffer getState(String key);
/**
* Retrieve the state value for the key, but don't wait for the operation to be completed
*
* @param key name of the key
* @return the state value for the key.
*/
CompletableFuture getStateAsync(String key);
/**
* Get a map of all user-defined key/value configs for the function.
*
* @return The full map of user-defined config values
*/
Map getUserConfigMap();
/**
* Get any user-defined key/value.
*
* @param key The key
* @return The Optional value specified by the user for that key.
*/
Optional