K
- State key typeV
- State value type@PublicEvolving public class QueryableStateStream<K,V> extends Object
Constructor and Description |
---|
QueryableStateStream(String queryableStateName,
org.apache.flink.api.common.state.StateDescriptor<?,V> stateDescriptor,
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer)
Creates a queryable state stream.
|
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.typeutils.TypeSerializer<K> |
getKeySerializer()
Returns the key serializer for the queryable state instance.
|
String |
getQueryableStateName()
Returns the name under which the state can be queried.
|
org.apache.flink.api.common.state.StateDescriptor<?,V> |
getStateDescriptor()
Returns the state descriptor for the queryable state instance.
|
public QueryableStateStream(String queryableStateName, org.apache.flink.api.common.state.StateDescriptor<?,V> stateDescriptor, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer)
queryableStateName
- Name under which to publish the queryable state instancestateDescriptor
- The state descriptor for the state instancekeySerializer
- Key serializer for the state instancepublic String getQueryableStateName()
public org.apache.flink.api.common.typeutils.TypeSerializer<K> getKeySerializer()
public org.apache.flink.api.common.state.StateDescriptor<?,V> getStateDescriptor()
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.