Uses of Class
uk.gov.gchq.gaffer.store.Context
-
-
Uses of Context in uk.gov.gchq.gaffer.accumulostore.operation.handler
Methods in uk.gov.gchq.gaffer.accumulostore.operation.handler with parameters of type Context Modifier and Type Method Description Void
AddElementsHandler. doOperation(AddElements operation, Context context, Store store)
Object
DeleteAllDataHandler. doOperation(DeleteAllData operation, Context context, Store store)
Object
DeleteElementsHandler. doOperation(DeleteElements operation, Context context, Store store)
Iterable<? extends EntityId>
GetAdjacentIdsHandler. doOperation(GetAdjacentIds operation, Context context, Store store)
Iterable<? extends Element>
GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)
Iterable<? extends Element>
GetElementsBetweenSetsHandler. doOperation(GetElementsBetweenSets operation, Context context, Store store)
Deprecated.Iterable<? extends Element>
GetElementsBetweenSetsPairsHandler. doOperation(GetElementsBetweenSetsPairs operation, Context context, Store store)
Iterable<? extends Element>
GetElementsHandler. doOperation(GetElements operation, Context context, Store store)
Iterable<? extends Element>
GetElementsInRangesHandler. doOperation(GetElementsInRanges operation, Context context, Store store)
Iterable<? extends Element>
GetElementsWithinSetHandler. doOperation(GetElementsWithinSet operation, Context context, Store store)
Iterable<? extends Element>
SummariseGroupOverRangesHandler. doOperation(SummariseGroupOverRanges operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler
Methods in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler with parameters of type Context Modifier and Type Method Description void
AddElementsFromHdfsHandler. doOperation(AddElementsFromHdfs operation, Context context, AccumuloStore store)
Void
AddElementsFromHdfsHandler. doOperation(AddElementsFromHdfs operation, Context context, Store store)
Void
ImportAccumuloKeyValueFilesHandler. doOperation(ImportAccumuloKeyValueFiles operation, Context context, Store store)
Void
SampleDataForSplitPointsHandler. doOperation(SampleDataForSplitPoints operation, Context context, Store store)
Void
SplitStoreFromIterableHandler. doOperation(SplitStoreFromIterable<String> operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federated.simple.operation.handler
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler with parameters of type Context Modifier and Type Method Description Object
EitherOperationHandler. doOperation(O operation, Context context, Store store)
If graph IDs are in the options the operation will be handled by aFederatedOperationHandler
, otherwise the original handler will be used e.g.Object
FederatedOperationHandler. doOperation(P operation, Context context, Store store)
O
FederatedOutputHandler. doOperation(P operation, Context context, Store store)
Map<String,O>
SeparateOutputHandler. doOperation(P operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federated.simple.operation.handler.add
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler.add with parameters of type Context Modifier and Type Method Description Void
AddGraphHandler. doOperation(AddGraph operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federated.simple.operation.handler.get
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler.get with parameters of type Context Modifier and Type Method Description Set<String>
GetAllGraphIdsHandler. doOperation(GetAllGraphIds operation, Context context, Store store)
Map<String,Object>
GetAllGraphInfoHandler. doOperation(GetAllGraphInfo operation, Context context, Store store)
Schema
GetSchemaHandler. doOperation(GetSchema operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federated.simple.operation.handler.misc
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler.misc with parameters of type Context Modifier and Type Method Description Object
ChangeGraphIdHandler. doOperation(ChangeGraphId operation, Context context, Store store)
Object
RemoveGraphHandler. doOperation(RemoveGraph operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federatedstore
Methods in uk.gov.gchq.gaffer.federatedstore with parameters of type Context Modifier and Type Method Description Schema
FederatedStore. getSchema(Context context, boolean getCompactSchema)
GetSchema
for this FederatedStore. -
Uses of Context in uk.gov.gchq.gaffer.federatedstore.operation.handler
Methods in uk.gov.gchq.gaffer.federatedstore.operation.handler with parameters of type Context Modifier and Type Method Description Void
FederatedAddGraphHandlerParent. doOperation(OP operation, Context context, Store store)
Iterable<? extends Element>
FederatedDelegateToHandler. doOperation(InputOutput<Iterable<? extends Element>,Iterable<? extends Element>> operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federatedstore.operation.handler.impl
Methods in uk.gov.gchq.gaffer.federatedstore.operation.handler.impl with parameters of type Context Modifier and Type Method Description Boolean
FederatedChangeGraphAccessHandler. doOperation(ChangeGraphAccess operation, Context context, Store store)
Boolean
FederatedChangeGraphIdHandler. doOperation(ChangeGraphId operation, Context context, Store store)
Iterable<? extends String>
FederatedGetAllGraphIDHandler. doOperation(GetAllGraphIds operation, Context context, Store store)
Map<String,Object>
FederatedGetAllGraphInfoHandler. doOperation(GetAllGraphInfo operation, Context context, Store store)
Void
FederatedNoOutputHandler. doOperation(PAYLOAD operation, Context context, Store store)
The Operation with no output is wrapped in a defaulted FederatedOperation and re-executed.Object
FederatedOperationHandler. doOperation(FederatedOperation<INPUT,OUTPUT> operation, Context context, Store store)
OUTPUT
FederatedOutputHandler. doOperation(PAYLOAD operation, Context context, Store store)
Boolean
FederatedRemoveGraphAndDeleteAllDataHandler. doOperation(RemoveGraph operation, Context context, Store store)
Boolean
FederatedRemoveGraphHandler. doOperation(RemoveGraph operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.federatedstore.util
Methods in uk.gov.gchq.gaffer.federatedstore.util with parameters of type Context Modifier and Type Method Description static BiFunction
FederatedStoreUtil. getStoreConfiguredMergeFunction(Operation payload, Context context, List graphIds, FederatedStore store)
static BiFunction
FederatedStoreUtil. processIfFunctionIsContextSpecific(BiFunction mergeFunction, Operation payload, Context operationContext, List<String> graphIds, FederatedStore federatedStore)
static <OP extends Operation>
OPFederatedStoreUtil. updateOperationForGraph(OP operation, Graph graph, Context context)
Within FederatedStore anOperation
is executed against a collection of many graphs. -
Uses of Context in uk.gov.gchq.gaffer.flink.operation.handler
Methods in uk.gov.gchq.gaffer.flink.operation.handler with parameters of type Context Modifier and Type Method Description Object
AddElementsFromFileHandler. doOperation(AddElementsFromFile op, Context context, Store store)
Object
AddElementsFromKafkaHandler. doOperation(AddElementsFromKafka op, Context context, Store store)
Object
AddElementsFromSocketHandler. doOperation(AddElementsFromSocket op, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.graph
Methods in uk.gov.gchq.gaffer.graph that return Context Modifier and Type Method Description Context
GraphRequest. getContext()
Context
GraphResult. getContext()
Methods in uk.gov.gchq.gaffer.graph with parameters of type Context Modifier and Type Method Description <O> O
Graph. execute(Output<O> operation, Context context)
Performs the given output operation on the store.void
Graph. execute(Operation operation, Context context)
Performs the given operation on the store.JobDetail
Graph. executeJob(Job job, Context context)
Performs the given Job on the store.JobDetail
Graph. executeJob(Operation operation, Context context)
Performs the given operation job on the store.Constructors in uk.gov.gchq.gaffer.graph with parameters of type Context Constructor Description GraphRequest(Output<O> operation, Context context)
GraphRequest(Operation operation, Context context)
GraphResult(O result, Context context)
-
Uses of Context in uk.gov.gchq.gaffer.graph.hook
Methods in uk.gov.gchq.gaffer.graph.hook with parameters of type Context Modifier and Type Method Description <T> T
AddOperationsToChain. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
default <T> T
GraphHook. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
Called fromGraph
if an error occurs whilst executing theOperationChain
.<T> T
GraphHookPath. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
Log4jLogger. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
NamedOperationResolver. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
NamedViewResolver. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
OperationAuthoriser. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
OperationChainLimiter. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
UpdateViewHook. onFailure(T result, OperationChain<?> opChain, Context context, Exception e)
<T> T
AddOperationsToChain. postExecute(T result, OperationChain<?> opChain, Context context)
default <T> T
GraphHook. postExecute(T result, OperationChain<?> opChain, Context context)
Called fromGraph
after anOperationChain
is executed.<T> T
GraphHookPath. postExecute(T result, OperationChain<?> opChain, Context context)
<T> T
Log4jLogger. postExecute(T result, OperationChain<?> operationChain, Context context)
<T> T
NamedOperationResolver. postExecute(T result, OperationChain<?> opChain, Context context)
<T> T
NamedViewResolver. postExecute(T result, OperationChain<?> opChain, Context context)
<T> T
OperationAuthoriser. postExecute(T result, OperationChain<?> opChain, Context context)
<T> T
OperationChainLimiter. postExecute(T result, OperationChain<?> opChain, Context context)
<T> T
UpdateViewHook. postExecute(T result, OperationChain<?> opChain, Context context)
void
AddOperationsToChain. preExecute(OperationChain<?> opChain, Context context)
Adds in the additional Operations specified.void
FunctionAuthoriser. preExecute(OperationChain<?> opChain, Context context)
default void
GraphHook. preExecute(OperationChain<?> opChain, Context context)
Called fromGraph
before anOperationChain
is executed.void
GraphHookPath. preExecute(OperationChain<?> opChain, Context context)
void
Log4jLogger. preExecute(OperationChain<?> opChain, Context context)
Logs the operation chain and the user id.void
NamedOperationResolver. preExecute(OperationChain<?> opChain, Context context)
void
NamedViewResolver. preExecute(OperationChain<?> opChain, Context context)
void
OperationAuthoriser. preExecute(OperationChain<?> opChain, Context context)
Checks theOperation
s in the providedOperationChain
are allowed to be executed by the user.void
OperationChainLimiter. preExecute(OperationChain<?> opChain, Context context)
Checks theOperationChain
is allowed to be executed by the user.void
UpdateViewHook. preExecute(OperationChain<?> opChain, Context context)
-
Uses of Context in uk.gov.gchq.gaffer.graph.hook.migrate
Methods in uk.gov.gchq.gaffer.graph.hook.migrate with parameters of type Context Modifier and Type Method Description void
SchemaMigration. preExecute(OperationChain<?> opChain, Context context)
-
Uses of Context in uk.gov.gchq.gaffer.hdfs.operation.handler
Methods in uk.gov.gchq.gaffer.hdfs.operation.handler with parameters of type Context Modifier and Type Method Description List<String>
HdfsSplitStoreFromFileHandler. getSplits(SplitStoreFromFile operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.mapstore.impl
Methods in uk.gov.gchq.gaffer.mapstore.impl with parameters of type Context Modifier and Type Method Description Void
AddElementsHandler. doOperation(AddElements addElements, Context context, Store store)
Long
CountAllElementsDefaultViewHandler. doOperation(CountAllElementsDefaultView operation, Context context, Store store)
Object
DeleteAllDataHandler. doOperation(DeleteAllData operation, Context context, Store store)
Object
DeleteElementsHandler. doOperation(DeleteElements deleteElements, Context context, Store store)
Iterable<? extends EntityId>
GetAdjacentIdsHandler. doOperation(GetAdjacentIds operation, Context context, Store store)
Iterable<? extends Element>
GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)
Iterable<Element>
GetElementsHandler. doOperation(GetElements operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.operation.export.graph
Constructors in uk.gov.gchq.gaffer.operation.export.graph with parameters of type Context Constructor Description OtherGraphExporter(Context context, Graph graph)
-
Uses of Context in uk.gov.gchq.gaffer.operation.export.resultcache
Constructors in uk.gov.gchq.gaffer.operation.export.resultcache with parameters of type Context Constructor Description GafferResultCacheExporter(Context context, String jobId, Graph resultCache, String visibility, Set<String> requiredOpAuths)
-
Uses of Context in uk.gov.gchq.gaffer.proxystore
Methods in uk.gov.gchq.gaffer.proxystore with parameters of type Context Modifier and Type Method Description JobDetail
ProxyStore. executeJob(OperationChain<?> operationChain, Context context)
<O> O
ProxyStore. executeOpChainViaUrl(OperationChain<O> opChain, Context context)
-
Uses of Context in uk.gov.gchq.gaffer.proxystore.operation.handler
Methods in uk.gov.gchq.gaffer.proxystore.operation.handler with parameters of type Context Modifier and Type Method Description Map<String,Object>
GetProxyPropertiesHandler. doOperation(GetProxyProperties operation, Context context, Store store)
This implementation could work with with any store and properties but gets ONLY the Proxy Properties value from the Proxy store.String
GetProxyUrlHandler. doOperation(GetProxyUrl operation, Context context, Store store)
OUT
OperationChainHandler. doOperation(OperationChain<OUT> operationChain, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.rest.factory
Methods in uk.gov.gchq.gaffer.rest.factory that return Context Modifier and Type Method Description default Context
UserFactory. createContext()
Create a newContext
object. -
Uses of Context in uk.gov.gchq.gaffer.spark
Methods in uk.gov.gchq.gaffer.spark that return Context Modifier and Type Method Description static Context
SparkContextUtil. createContext(User user, org.apache.spark.sql.SparkSession sparkSession)
Create a new Context with the given user and spark session.static Context
SparkContextUtil. createContext(User user, StoreProperties storeProperties)
Create a new Context with the given user and store propertiesMethods in uk.gov.gchq.gaffer.spark with parameters of type Context Modifier and Type Method Description static void
SparkContextUtil. addSparkSession(Context context, org.apache.spark.sql.SparkSession sparkSession)
Adds a spark session to the givenContext
.static void
SparkContextUtil. addSparkSession(Context context, StoreProperties storeProperties)
Adds a spark session to the givenContext
.static org.apache.spark.sql.SparkSession
SparkContextUtil. getSparkSession(Context context, StoreProperties properties)
Extracts theSparkSession
from the Context. -
Uses of Context in uk.gov.gchq.gaffer.spark.operation.handler.graphframe
Methods in uk.gov.gchq.gaffer.spark.operation.handler.graphframe with parameters of type Context Modifier and Type Method Description org.graphframes.GraphFrame
GetGraphFrameOfElementsHandler. doOperation(GetGraphFrameOfElements operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler with parameters of type Context Modifier and Type Method Description void
AbstractImportKeyValuePairRDDToAccumuloHandler. doOperation(OP operation, Context context, AccumuloStore store)
Void
AbstractImportKeyValuePairRDDToAccumuloHandler. doOperation(OP operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframe
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframe with parameters of type Context Modifier and Type Method Description org.apache.spark.sql.Dataset<org.apache.spark.sql.Row>
GetDataFrameOfElementsHandler. doOperation(GetDataFrameOfElements operation, Context context, AccumuloStore store)
org.apache.spark.sql.Dataset<org.apache.spark.sql.Row>
GetDataFrameOfElementsHandler. doOperation(GetDataFrameOfElements operation, Context context, Store store)
Constructors in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframe with parameters of type Context Constructor Description AccumuloStoreRelation(Context context, List<Converter> converters, View view, AccumuloStore store, Map<String,String> options)
-
Uses of Context in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd with parameters of type Context Modifier and Type Method Description org.apache.spark.api.java.JavaRDD<Element>
GetJavaRDDOfAllElementsHandler. doOperation(GetJavaRDDOfAllElements operation, Context context, Store store)
org.apache.spark.api.java.JavaRDD<Element>
GetJavaRDDOfElementsHandler. doOperation(GetJavaRDDOfElements operation, Context context, Store store)
org.apache.spark.api.java.JavaRDD<Element>
GetJavaRDDOfElementsInRangesHandler. doOperation(GetJavaRDDOfElementsInRanges operation, Context context, Store store)
void
ImportJavaRDDOfElementsHandler. doOperation(ImportJavaRDDOfElements operation, Context context, AccumuloStore store)
Void
ImportJavaRDDOfElementsHandler. doOperation(ImportJavaRDDOfElements operation, Context context, Store store)
Void
SplitStoreFromJavaRDDOfElementsHandler. doOperation(SplitStoreFromJavaRDDOfElements operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd with parameters of type Context Modifier and Type Method Description org.apache.spark.rdd.RDD<Element>
GetRDDOfAllElementsHandler. doOperation(GetRDDOfAllElements operation, Context context, Store store)
org.apache.spark.rdd.RDD<Element>
GetRDDOfElementsHandler. doOperation(GetRDDOfElements operation, Context context, Store store)
org.apache.spark.rdd.RDD<Element>
GetRDDOfElementsInRangesHandler. doOperation(GetRDDOfElementsInRanges operation, Context context, Store store)
void
ImportRDDOfElementsHandler. doOperation(ImportRDDOfElements operation, Context context, AccumuloStore store)
Void
ImportRDDOfElementsHandler. doOperation(ImportRDDOfElements operation, Context context, Store store)
Void
SplitStoreFromRDDOfElementsHandler. doOperation(SplitStoreFromRDDOfElements operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store
Methods in uk.gov.gchq.gaffer.store that return Context Modifier and Type Method Description Context
Context.Builder. build()
Context
Store. createContext(User user)
Context
Context. shallowClone()
Creates a clone of the currentContext
and returns it with a new job ID.Methods in uk.gov.gchq.gaffer.store with parameters of type Context Modifier and Type Method Description <O> O
Store. execute(Output<O> operation, Context context)
Executes a given operation and returns the result.void
Store. execute(Operation operation, Context context)
Executes a given operation and returns the result.JobDetail
Store. executeJob(Job job, Context context)
JobDetail
Store. executeJob(Operation operation, Context context)
Executes a given operation job and returns the job detail.Object
Store. handleOperation(Operation operation, Context context)
Constructors in uk.gov.gchq.gaffer.store with parameters of type Context Constructor Description Context(Context context)
Create a newContext
based on the provided context. -
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler
Methods in uk.gov.gchq.gaffer.store.operation.handler with parameters of type Context Modifier and Type Method Description Object
WhileHandler. doDelegateOperation(Object input, Operation delegate, Context context, Store store)
List<T>
AbstractGenerateSplitPointsFromSampleHandler. doOperation(GenerateSplitPointsFromSample<T> operation, Context context, Store store)
List<T>
AbstractSampleElementsForSplitPointsHandler. doOperation(SampleElementsForSplitPoints<T> operation, Context context, Store store)
Void
AddSchemaToLibraryHandler. doOperation(AddSchemaToLibrary operation, Context context, Store store)
Void
AddStorePropertiesToLibraryHandler. doOperation(AddStorePropertiesToLibrary operation, Context context, Store store)
GroupCounts
CountGroupsHandler. doOperation(CountGroups operation, Context context, Store store)
Long
CountHandler. doOperation(Count operation, Context context, Store store)
Void
DiscardOutputHandler. doOperation(DiscardOutput operation, Context context, Store store)
Iterable<? extends O>
ForEachHandler. doOperation(ForEach<I,O> forEach, Context context, Store store)
String
GetFromEndpointHandler. doOperation(GetFromEndpoint operation, Context context, Store store)
Map<String,String>
GetGraphCreatedTimeHandler. doOperation(GetGraphCreatedTime operation, Context context, Store store)
Schema
GetSchemaHandler. doOperation(GetSchema operation, Context context, Store store)
Set<StoreTrait>
GetTraitsHandler. doOperation(GetTraits operation, Context context, Store store)
Object
GetVariableHandler. doOperation(GetVariable operation, Context context, Store store)
Map<String,Object>
GetVariablesHandler. doOperation(GetVariables operation, Context context, Store store)
Iterable<Walk>
GetWalksHandler. doOperation(GetWalks getWalks, Context context, Store store)
Boolean
HasTraitHandler. doOperation(HasTrait operation, Context context, Store store)
Object
IfHandler. doOperation(If operation, Context context, Store store)
Iterable<? extends T>
LimitHandler. doOperation(Limit<T> operation, Context context, Store store)
O
MapHandler. doOperation(Map<I,O> operation, Context context, Store store)
Handles theMap
operation.OUT
OperationChainHandler. doOperation(OperationChain<OUT> operationChain, Context context, Store store)
Object
OperationHandler. doOperation(OP operation, Context context, Store store)
Execute the givenOperation
.O
OutputOperationHandler. doOperation(OP operation, Context context, Store store)
Execute the givenOutput
operation.T
ReduceHandler. doOperation(Reduce<T> operation, Context context, Store store)
Handles theReduce
operation.Integer
ScoreOperationChainHandler. doOperation(ScoreOperationChain operation, Context context, Store store)
Returns the OperationChainLimiter score for the OperationChain provided.Void
SetVariableHandler. doOperation(SetVariable operation, Context context, Store store)
Void
SplitStoreFromFileHandler. doOperation(SplitStoreFromFile operation, Context context, Store store)
Iterable<? extends Element>
ValidateHandler. doOperation(Validate operation, Context context, Store store)
uk.gov.gchq.koryphe.ValidationResult
ValidateOperationChainHandler. doOperation(ValidateOperationChain operation, Context context, Store store)
Returns aValidationResult
for the supplied OperationChain.Object
WhileHandler. doOperation(While operation, Context context, Store store)
List<String>
SplitStoreFromFileHandler. getSplits(SplitStoreFromFile operation, Context context, Store store)
boolean
WhileHandler. isSatisfied(Object input, While operation, Context context, Store store)
<O> OperationChain<O>
OperationChainHandler. prepareOperationChain(OperationChain<O> operationChain, Context context, Store store)
void
SplitStoreFromFileHandler. splitStoreFromIterable(Iterable<String> splits, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.compare
Methods in uk.gov.gchq.gaffer.store.operation.handler.compare with parameters of type Context Modifier and Type Method Description Element
MaxHandler. doOperation(Max operation, Context context, Store store)
Element
MinHandler. doOperation(Min operation, Context context, Store store)
Iterable<? extends Element>
SortHandler. doOperation(Sort operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.export
Methods in uk.gov.gchq.gaffer.store.operation.handler.export with parameters of type Context Modifier and Type Method Description Object
ExportOperationHandler. doOperation(EXPORT export, Context context, Store store)
Object
ExportToHandler. doOperation(EXPORT export, Context context, Store store, EXPORTER exporter)
Iterable<?>
GetExportHandler. doOperation(EXPORT export, Context context, Store store, EXPORTER exporter)
Map<String,Iterable<?>>
GetExportsHandler. doOperation(GetExports getExports, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.export.localfile
Methods in uk.gov.gchq.gaffer.store.operation.handler.export.localfile with parameters of type Context Modifier and Type Method Description LocalFileExporter
ImportFromLocalFileHandler. createExporter(ImportFromLocalFile importOp, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.export.set
Methods in uk.gov.gchq.gaffer.store.operation.handler.export.set with parameters of type Context Modifier and Type Method Description SetExporter
GetSetExportHandler. createExporter(GetSetExport export, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.function
Methods in uk.gov.gchq.gaffer.store.operation.handler.function with parameters of type Context Modifier and Type Method Description Iterable<? extends Element>
AggregateHandler. doOperation(Aggregate operation, Context context, Store store)
Iterable<? extends Element>
FilterHandler. doOperation(Filter operation, Context context, Store store)
Iterable<? extends Element>
TransformHandler. doOperation(Transform operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.generate
Methods in uk.gov.gchq.gaffer.store.operation.handler.generate with parameters of type Context Modifier and Type Method Description Iterable<? extends Element>
GenerateElementsHandler. doOperation(GenerateElements<OBJ> operation, Context context, Store store)
Iterable<? extends OBJ>
GenerateObjectsHandler. doOperation(GenerateObjects<OBJ> operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.job
Methods in uk.gov.gchq.gaffer.store.operation.handler.job with parameters of type Context Modifier and Type Method Description Void
CancelScheduledJobHandler. doOperation(CancelScheduledJob operation, Context context, Store store)
Iterable<JobDetail>
GetAllJobDetailsHandler. doOperation(GetAllJobDetails operation, Context context, Store store)
JobDetail
GetJobDetailsHandler. doOperation(GetJobDetails operation, Context context, Store store)
Iterable<?>
GetJobResultsHandler. doOperation(GetJobResults operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.join
Methods in uk.gov.gchq.gaffer.store.operation.handler.join with parameters of type Context Modifier and Type Method Description Iterable<? extends uk.gov.gchq.koryphe.tuple.MapTuple>
JoinHandler. doOperation(Join<I> operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.named
Methods in uk.gov.gchq.gaffer.store.operation.handler.named with parameters of type Context Modifier and Type Method Description Void
AddNamedOperationHandler. doOperation(AddNamedOperation operation, Context context, Store store)
Adds a NamedOperation to a cache which must be specified in the operation declarations file.Object
AddNamedViewHandler. doOperation(AddNamedView operation, Context context, Store store)
Adds aNamedViewDetail
to the NamedViewCache.Void
DeleteNamedOperationHandler. doOperation(DeleteNamedOperation operation, Context context, Store store)
Deletes a NamedOperation from the cache specified in the Operations Declarations file (assuming the user has write privileges on the specified NamedOperation).Void
DeleteNamedViewHandler. doOperation(DeleteNamedView namedViewOp, Context context, Store store)
Deletes a NamedView from the NamedViewCache.Iterable<NamedOperationDetail>
GetAllNamedOperationsHandler. doOperation(GetAllNamedOperations operation, Context context, Store store)
Retrieves all the Named Operations that a user is allowed to see.Iterable<NamedViewDetail>
GetAllNamedViewsHandler. doOperation(GetAllNamedViews operation, Context context, Store store)
Gets all NamedViews from the NamedViewCache.Object
NamedOperationHandler. doOperation(NamedOperation<?,Object> operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.output
Methods in uk.gov.gchq.gaffer.store.operation.handler.output with parameters of type Context Modifier and Type Method Description T[]
ToArrayHandler. doOperation(ToArray<T> operation, Context context, Store store)
Iterable<? extends String>
ToCsvHandler. doOperation(ToCsv operation, Context context, Store store)
Iterable<EntitySeed>
ToEntitySeedsHandler. doOperation(ToEntitySeeds operation, Context context, Store store)
List<T>
ToListHandler. doOperation(ToList<T> operation, Context context, Store store)
Iterable<? extends Map<String,Object>>
ToMapHandler. doOperation(ToMap operation, Context context, Store store)
Set<T>
ToSetHandler. doOperation(ToSet<T> operation, Context context, Store store)
List<? extends T>
ToSingletonListHandler. doOperation(ToSingletonList<T> operation, Context context, Store store)
Stream<? extends T>
ToStreamHandler. doOperation(ToStream<T> operation, Context context, Store store)
Iterable<Object>
ToVerticesHandler. doOperation(ToVertices operation, Context context, Store store)
-
Uses of Context in uk.gov.gchq.gaffer.store.operation.handler.util
Methods in uk.gov.gchq.gaffer.store.operation.handler.util with parameters of type Context Modifier and Type Method Description static Object
OperationHandlerUtil. getResultsOrNull(Operation op, Context context, Store store)
Executes and operation on the store and returns the results or null.
-