Uses of Class
uk.gov.gchq.gaffer.data.element.Element
-
-
Uses of Element in uk.gov.gchq.gaffer.accumulostore
Method parameters in uk.gov.gchq.gaffer.accumulostore with type arguments of type Element Modifier and Type Method Description void
AccumuloStore. addElements(Iterable<? extends Element> elements)
Method to addElement
s into Accumulo.void
AccumuloStore. deleteElements(Iterable<? extends Element> elements)
Method to deleteElement
s from Accumulo. -
Uses of Element in uk.gov.gchq.gaffer.accumulostore.data.element
Methods in uk.gov.gchq.gaffer.accumulostore.data.element with parameters of type Element Modifier and Type Method Description void
AccumuloEdgeValueLoader. loadIdentifiers(Element edge)
void
AccumuloEntityValueLoader. loadIdentifiers(Element entity)
-
Uses of Element in uk.gov.gchq.gaffer.accumulostore.inputformat
Methods in uk.gov.gchq.gaffer.accumulostore.inputformat that return types with arguments of type Element Modifier and Type Method Description org.apache.hadoop.mapreduce.RecordReader<Element,org.apache.hadoop.io.NullWritable>
ElementInputFormat. createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context)
Methods in uk.gov.gchq.gaffer.accumulostore.inputformat with parameters of type Element Modifier and Type Method Description static boolean
ElementInputFormat. doPostFilter(Element element, View view)
static boolean
ElementInputFormat. postFilter(Element element, ElementFilter postFilter)
-
Uses of Element in uk.gov.gchq.gaffer.accumulostore.key
Methods in uk.gov.gchq.gaffer.accumulostore.key that return Element Modifier and Type Method Description Element
AccumuloElementConverter. getElementFromKey(org.apache.accumulo.core.data.Key key, boolean includeMatchedVertex)
Gets a newElement
from an AccumuloKey
.Element
AccumuloElementConverter. getFullElement(org.apache.accumulo.core.data.Key key, org.apache.accumulo.core.data.Value value, boolean includeMatchedVertex)
Methods in uk.gov.gchq.gaffer.accumulostore.key with parameters of type Element Modifier and Type Method Description Pair<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Key>
AccumuloElementConverter. getKeysFromElement(Element element)
Pair<byte[],byte[]>
AccumuloElementConverter. getRowKeysFromElement(Element element)
Creates a byte array representing the Element identifiers, this will be stored in the Accumulo row Key.org.apache.accumulo.core.data.Value
AccumuloElementConverter. getValueFromElement(Element element)
Converts theProperties
in an element to an AccumuloValue
where the property has a position within the store schema that indicates it should be stored in the value. -
Uses of Element in uk.gov.gchq.gaffer.accumulostore.key.core
Methods in uk.gov.gchq.gaffer.accumulostore.key.core that return Element Modifier and Type Method Description Element
AbstractCoreKeyAccumuloElementConverter. getElementFromKey(org.apache.accumulo.core.data.Key key, boolean includeMatchedVertex)
Element
AbstractCoreKeyAccumuloElementConverter. getFullElement(org.apache.accumulo.core.data.Key key, org.apache.accumulo.core.data.Value value, boolean includeMatchedVertex)
Methods in uk.gov.gchq.gaffer.accumulostore.key.core with parameters of type Element Modifier and Type Method Description Pair<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Key>
AbstractCoreKeyAccumuloElementConverter. getKeysFromElement(Element element)
Pair<byte[],byte[]>
AbstractCoreKeyAccumuloElementConverter. getRowKeysFromElement(Element element)
org.apache.accumulo.core.data.Value
AbstractCoreKeyAccumuloElementConverter. getValueFromElement(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.accumulostore.operation.handler
Methods in uk.gov.gchq.gaffer.accumulostore.operation.handler that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)
Iterable<? extends Element>
GetAllElementsHandler. doOperation(GetAllElements operation, User user, AccumuloStore store)
Iterable<? extends Element>
GetElementsBetweenSetsHandler. doOperation(GetElementsBetweenSets operation, Context context, Store store)
Deprecated.Iterable<? extends Element>
GetElementsBetweenSetsHandler. doOperation(GetElementsBetweenSets operation, User user, AccumuloStore store)
Deprecated.Iterable<? extends Element>
GetElementsBetweenSetsPairsHandler. doOperation(GetElementsBetweenSetsPairs operation, Context context, Store store)
Iterable<? extends Element>
GetElementsBetweenSetsPairsHandler. doOperation(GetElementsBetweenSetsPairs operation, User user, AccumuloStore store)
Iterable<? extends Element>
GetElementsHandler. doOperation(GetElements operation, Context context, Store store)
Iterable<? extends Element>
GetElementsHandler. doOperation(GetElements operation, User user, AccumuloStore store)
Iterable<? extends Element>
GetElementsInRangesHandler. doOperation(GetElementsInRanges operation, Context context, Store store)
Iterable<? extends Element>
GetElementsInRangesHandler. doOperation(GetElementsInRanges operation, User user, AccumuloStore store)
Iterable<? extends Element>
GetElementsWithinSetHandler. doOperation(GetElementsWithinSet operation, Context context, Store store)
Iterable<? extends Element>
GetElementsWithinSetHandler. doOperation(GetElementsWithinSet operation, User user, AccumuloStore store)
Iterable<? extends Element>
SummariseGroupOverRangesHandler. doOperation(SummariseGroupOverRanges operation, Context context, Store store)
Iterable<? extends Element>
SummariseGroupOverRangesHandler. doOperation(SummariseGroupOverRanges operation, User user, AccumuloStore store)
-
Uses of Element in uk.gov.gchq.gaffer.accumulostore.operation.impl
Methods in uk.gov.gchq.gaffer.accumulostore.operation.impl that return types with arguments of type Element Modifier and Type Method Description com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GetElementsBetweenSets. getOutputTypeReference()
Deprecated.com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GetElementsBetweenSetsPairs. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GetElementsInRanges. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GetElementsWithinSet. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
SummariseGroupOverRanges. getOutputTypeReference()
-
Uses of Element in uk.gov.gchq.gaffer.accumulostore.retriever
Classes in uk.gov.gchq.gaffer.accumulostore.retriever with type parameters of type Element Modifier and Type Class Description class
AccumuloItemRetriever<OP extends Output<Iterable<? extends Element>> & GraphFilters,I_ITEM>
class
AccumuloSetRetriever<OP extends InputOutput<Iterable<? extends EntityId>,Iterable<? extends Element>> & GraphFilters>
Methods in uk.gov.gchq.gaffer.accumulostore.retriever that return types with arguments of type Element Modifier and Type Method Description Iterator<Element>
AccumuloItemRetriever. iterator()
Only 1 iterator can be open at a time.Iterator<Element>
AccumuloSetRetriever. iterator()
Only 1 iterator can be open at a time.Methods in uk.gov.gchq.gaffer.accumulostore.retriever with parameters of type Element Modifier and Type Method Description boolean
AccumuloRetriever. doPostFilter(Element element)
Performs any post Filtering specified in a view on an elementvoid
AccumuloRetriever. doTransformation(Element element)
Performs any transformations specified in a view on an element -
Uses of Element in uk.gov.gchq.gaffer.accumulostore.retriever.impl
Classes in uk.gov.gchq.gaffer.accumulostore.retriever.impl with type parameters of type Element Modifier and Type Class Description class
AccumuloRangeIDRetriever<OP extends InputOutput<Iterable<? extends Pair<? extends ElementId,? extends ElementId>>,Iterable<? extends Element>> & GraphFilters>
This allows queries for all data from between the providedElementId
pairs.class
AccumuloSingleIDRetriever<OP extends InputOutput<Iterable<? extends ElementId>,Iterable<? extends Element>> & GraphFilters>
This allows queries for all data related to the providedElementId
s.Methods in uk.gov.gchq.gaffer.accumulostore.retriever.impl that return types with arguments of type Element Modifier and Type Method Description Iterator<Element>
AccumuloAllElementsRetriever. iterator()
Only 1 iterator can be open at a time. -
Uses of Element in uk.gov.gchq.gaffer.data
Methods in uk.gov.gchq.gaffer.data with parameters of type Element Modifier and Type Method Description boolean
IsEdgeValidator. validate(Element element)
boolean
IsEntityValidator. validate(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.data.element
Subclasses of Element in uk.gov.gchq.gaffer.data.element Modifier and Type Class Description class
Edge
AnEdge
in anElement
containing a source, destination and a directed flag.class
Entity
AnEntity
in anElement
containing a single vertex.class
LazyEdge
AnLazyEdge
wraps anEdge
and lazily loads identifiers and properties when requested using a providedElementValueLoader
.class
LazyEntity
AnLazyEntity
wraps anEntity
and lazily loads the identifier and properties when requested using a providedElementValueLoader
.Methods in uk.gov.gchq.gaffer.data.element that return Element Modifier and Type Method Description abstract Element
Element. emptyClone()
Element
Element. getElement()
Element
ElementTuple. getElement()
Element
Element. shallowClone()
Methods in uk.gov.gchq.gaffer.data.element with parameters of type Element Modifier and Type Method Description void
ElementValueLoader. loadIdentifiers(Element element)
The loaded identifiers should be set on the provided elementvoid
ElementTuple. setElement(Element element)
boolean
Element. shallowEquals(Element element)
Constructors in uk.gov.gchq.gaffer.data.element with parameters of type Element Constructor Description ElementTuple(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.data.element.comparison
Methods in uk.gov.gchq.gaffer.data.element.comparison with parameters of type Element Modifier and Type Method Description int
ElementPropertyComparator. compare(Element e1, Element e2)
boolean
ElementJoinComparator. test(Element element, Element element2)
-
Uses of Element in uk.gov.gchq.gaffer.data.element.function
Methods in uk.gov.gchq.gaffer.data.element.function that return Element Modifier and Type Method Description Element
ElementAggregator. apply(Element state, Element element)
Aggregates the element.Element
ElementTransformer. apply(Element element)
Methods in uk.gov.gchq.gaffer.data.element.function that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
ReduceRelatedElements. apply(Iterable<Element> elements)
Iterable<Element>
TuplesToElements. apply(Iterable<uk.gov.gchq.koryphe.tuple.Tuple<String>> tuples)
Iterable<Element>
TupleToElements. apply(uk.gov.gchq.koryphe.tuple.Tuple<String> tuple)
Methods in uk.gov.gchq.gaffer.data.element.function with parameters of type Element Modifier and Type Method Description Element
ElementAggregator. apply(Element state, Element element)
Aggregates the element.Element
ElementTransformer. apply(Element element)
String
ExtractGroup. apply(Element element)
Object
ExtractId. apply(Element element)
Object
ExtractProperty. apply(Element element)
ElementTuple
ToElementTuple. apply(Element element)
boolean
ElementFilter. test(Element element)
uk.gov.gchq.koryphe.ValidationResult
ElementFilter. testWithValidationResult(Element element)
Method parameters in uk.gov.gchq.gaffer.data.element.function with type arguments of type Element Modifier and Type Method Description Iterable<Element>
ReduceRelatedElements. apply(Iterable<Element> elements)
-
Uses of Element in uk.gov.gchq.gaffer.data.elementdefinition.view
Methods in uk.gov.gchq.gaffer.data.elementdefinition.view with parameters of type Element Modifier and Type Method Description static void
ViewUtil. removeProperties(ViewElementDefinition elDef, Element element)
Remove properties from the supplied element, according to theViewElementDefinition
.static void
ViewUtil. removeProperties(View view, Element element)
Remove properties from the supplied element, according to theViewElementDefinition
in theView
. -
Uses of Element in uk.gov.gchq.gaffer.data.generator
Methods in uk.gov.gchq.gaffer.data.generator that return Element Modifier and Type Method Description Element
JsonToElementGenerator. _apply(String json)
Element
OneToOneElementGenerator. _apply(OBJ domainObject)
Methods in uk.gov.gchq.gaffer.data.generator that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
OneToManyElementGenerator. _apply(OBJ domainObject)
default Iterable<? extends Element>
OneToManyElementGenerator. apply(Iterable<? extends OBJ> domainObjects)
default Iterable<? extends Element>
OneToOneElementGenerator. apply(Iterable<? extends OBJ> domainObjects)
Iterable<? extends Element>
OpenCypherCsvElementGenerator. apply(Iterable<? extends String> strings)
Methods in uk.gov.gchq.gaffer.data.generator with parameters of type Element Modifier and Type Method Description String
CsvGenerator. _apply(Element element)
Map<String,Object>
MapGenerator. _apply(Element element)
OBJ
OneToOneObjectGenerator. _apply(Element element)
Method parameters in uk.gov.gchq.gaffer.data.generator with type arguments of type Element Modifier and Type Method Description default Iterable<? extends OBJ>
OneToOneObjectGenerator. apply(Iterable<? extends Element> elements)
-
Uses of Element in uk.gov.gchq.gaffer.federated
Methods in uk.gov.gchq.gaffer.federated that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
IndexGenerator. _apply(Element element)
Methods in uk.gov.gchq.gaffer.federated with parameters of type Element Modifier and Type Method Description Iterable<Element>
IndexGenerator. _apply(Element element)
ElementId
ToElementSeed. apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.federated.simple.merge.operator
Methods in uk.gov.gchq.gaffer.federated.simple.merge.operator that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
ElementAggregateOperator. apply(Iterable<Element> update, Iterable<Element> state)
Method parameters in uk.gov.gchq.gaffer.federated.simple.merge.operator with type arguments of type Element Modifier and Type Method Description Iterable<Element>
ElementAggregateOperator. apply(Iterable<Element> update, Iterable<Element> state)
-
Uses of Element in uk.gov.gchq.gaffer.federatedstore.operation.handler
Methods in uk.gov.gchq.gaffer.federatedstore.operation.handler that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
FederatedDelegateToHandler. doOperation(InputOutput<Iterable<? extends Element>,Iterable<? extends Element>> operation, Context context, Store store)
Method parameters in uk.gov.gchq.gaffer.federatedstore.operation.handler with type arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
FederatedDelegateToHandler. doOperation(InputOutput<Iterable<? extends Element>,Iterable<? extends Element>> operation, Context context, Store store)
Iterable<? extends Element>
FederatedDelegateToHandler. doOperation(InputOutput<Iterable<? extends Element>,Iterable<? extends Element>> operation, Context context, Store store)
Constructor parameters in uk.gov.gchq.gaffer.federatedstore.operation.handler with type arguments of type Element Constructor Description FederatedDelegateToHandler(OutputOperationHandler<? extends InputOutput<Iterable<? extends Element>,Iterable<? extends Element>>,Iterable<? extends Element>> handler)
FederatedDelegateToHandler(OutputOperationHandler<? extends InputOutput<Iterable<? extends Element>,Iterable<? extends Element>>,Iterable<? extends Element>> handler)
FederatedDelegateToHandler(OutputOperationHandler<? extends InputOutput<Iterable<? extends Element>,Iterable<? extends Element>>,Iterable<? extends Element>> handler)
-
Uses of Element in uk.gov.gchq.gaffer.flink.operation.handler
Methods in uk.gov.gchq.gaffer.flink.operation.handler with parameters of type Element Modifier and Type Method Description void
GafferAdder. add(Element element)
void
GafferSink. invoke(Element element)
void
GafferOutput. writeRecord(Element element)
Method parameters in uk.gov.gchq.gaffer.flink.operation.handler with type arguments of type Element Modifier and Type Method Description void
GafferMapFunction. flatMap(T item, org.apache.flink.util.Collector<Element> out)
Constructor parameters in uk.gov.gchq.gaffer.flink.operation.handler with type arguments of type Element Constructor Description AddElementsFromFileHandler(org.apache.flink.api.common.io.RichOutputFormat<Element> outputFormat)
AddElementsFromKafkaHandler(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env, org.apache.flink.streaming.api.functions.sink.SinkFunction<Element> sink)
AddElementsFromSocketHandler(org.apache.flink.streaming.api.functions.sink.SinkFunction<Element> sink)
-
Uses of Element in uk.gov.gchq.gaffer.graph.hook.migrate.predicate
Methods in uk.gov.gchq.gaffer.graph.hook.migrate.predicate with parameters of type Element Modifier and Type Method Description boolean
TransformAndFilter. test(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.hdfs.operation.mapper.generator
Methods in uk.gov.gchq.gaffer.hdfs.operation.mapper.generator that return types with arguments of type Element Modifier and Type Method Description Function<Iterable<? extends OBJ>,Iterable<? extends Element>>
AvroMapperGenerator. getElementGenerator()
Function<Iterable<? extends String>,Iterable<? extends Element>>
TextMapperGenerator. getElementGenerator()
Iterable<? extends Element>
AvroMapperGenerator. getElements(org.apache.avro.mapred.AvroKey<OBJ> keyIn, org.apache.hadoop.io.NullWritable valueIn, org.apache.hadoop.mapreduce.MapContext<org.apache.avro.mapred.AvroKey<OBJ>,org.apache.hadoop.io.NullWritable,?,?> context)
Iterable<? extends Element>
MapperGenerator. getElements(KEY_IN keyIn, VALUE_IN valueIn, org.apache.hadoop.mapreduce.MapContext<KEY_IN,VALUE_IN,?,?> context)
Iterable<? extends Element>
TextMapperGenerator. getElements(org.apache.hadoop.io.LongWritable keyIn, org.apache.hadoop.io.Text valueIn, org.apache.hadoop.mapreduce.MapContext<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Text,?,?> context)
Method parameters in uk.gov.gchq.gaffer.hdfs.operation.mapper.generator with type arguments of type Element Modifier and Type Method Description void
AvroMapperGenerator. setElementGenerator(Function<Iterable<? extends OBJ>,Iterable<? extends Element>> elementGenerator)
void
TextMapperGenerator. setElementGenerator(Function<Iterable<? extends String>,Iterable<? extends Element>> elementGenerator)
Constructor parameters in uk.gov.gchq.gaffer.hdfs.operation.mapper.generator with type arguments of type Element Constructor Description AvroMapperGenerator(Function<Iterable<? extends OBJ>,Iterable<? extends Element>> elementGenerator)
TextMapperGenerator(Function<Iterable<? extends String>,Iterable<? extends Element>> elementGenerator)
-
Uses of Element in uk.gov.gchq.gaffer.mapstore.factory
Methods in uk.gov.gchq.gaffer.mapstore.factory that return Element Modifier and Type Method Description Element
MapFactory. cloneElement(Element element, Schema schema)
Clone an element.Element
SimpleMapFactory. cloneElement(Element element, Schema schema)
Methods in uk.gov.gchq.gaffer.mapstore.factory with parameters of type Element Modifier and Type Method Description Element
MapFactory. cloneElement(Element element, Schema schema)
Clone an element.Element
SimpleMapFactory. cloneElement(Element element, Schema schema)
-
Uses of Element in uk.gov.gchq.gaffer.mapstore.impl
Methods in uk.gov.gchq.gaffer.mapstore.impl that return types with arguments of type Element Modifier and Type Method Description static Stream<Element>
GetElementsUtil. applyDirectedTypeFilter(Stream<Element> elements, boolean includeEdges, DirectedType directedType)
static Stream<Element>
GetElementsUtil. applyView(Stream<Element> elementStream, Schema schema, View view)
static Stream<Element>
GetElementsUtil. applyView(Stream<Element> elementStream, Schema schema, View view, boolean includeMatchedVertex)
static Stream<Element>
GetElementsUtil. applyVisibilityFilter(Stream<Element> elements, Schema schema, User user)
Iterable<? extends Element>
GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)
Iterable<Element>
GetElementsHandler. doOperation(GetElements operation, Context context, Store store)
static Set<Element>
GetElementsUtil. getRelevantElements(MapImpl mapImpl, ElementId elementId, View view, DirectedType directedType, SeededGraphFilters.IncludeIncomingOutgoingType inOutType)
Method parameters in uk.gov.gchq.gaffer.mapstore.impl with type arguments of type Element Modifier and Type Method Description static Stream<Element>
GetElementsUtil. applyDirectedTypeFilter(Stream<Element> elements, boolean includeEdges, DirectedType directedType)
static Stream<Element>
GetElementsUtil. applyView(Stream<Element> elementStream, Schema schema, View view)
static Stream<Element>
GetElementsUtil. applyView(Stream<Element> elementStream, Schema schema, View view, boolean includeMatchedVertex)
static Stream<Element>
GetElementsUtil. applyVisibilityFilter(Stream<Element> elements, Schema schema, User user)
-
Uses of Element in uk.gov.gchq.gaffer.mapstore.operation
Methods in uk.gov.gchq.gaffer.mapstore.operation that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
CountAllElementsDefaultView. getInput()
Method parameters in uk.gov.gchq.gaffer.mapstore.operation with type arguments of type Element Modifier and Type Method Description void
CountAllElementsDefaultView. setInput(Iterable<? extends Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.mapstore.utils
Methods in uk.gov.gchq.gaffer.mapstore.utils that return Element Modifier and Type Method Description Element
ElementCloner. cloneElement(Element element, Schema schema)
Methods in uk.gov.gchq.gaffer.mapstore.utils with parameters of type Element Modifier and Type Method Description Element
ElementCloner. cloneElement(Element element, Schema schema)
-
Uses of Element in uk.gov.gchq.gaffer.operation.data.generator
Methods in uk.gov.gchq.gaffer.operation.data.generator with parameters of type Element Modifier and Type Method Description EdgeId
EdgeIdExtractor. _apply(Element element)
EntityId
EntityIdExtractor. _apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.operation.export.graph
Methods in uk.gov.gchq.gaffer.operation.export.graph that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
ExportToOtherAuthorisedGraph. getInput()
Iterable<? extends Element>
ExportToOtherGraph. getInput()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
ExportToOtherAuthorisedGraph. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
ExportToOtherGraph. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.operation.export.graph with type arguments of type Element Modifier and Type Method Description void
ExportToOtherAuthorisedGraph. setInput(Iterable<? extends Element> input)
void
ExportToOtherGraph. setInput(Iterable<? extends Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.operation.graph
Methods in uk.gov.gchq.gaffer.operation.graph with parameters of type Element Modifier and Type Method Description default boolean
OperationView. validate(Element element)
default boolean
OperationView. validatePostAggregationFilter(Element element)
Validates an element against the post aggregation filters contained in the operation View.default boolean
OperationView. validatePostTransformFilter(Element element)
Validates an element against the post transform filters contained in the operation View.default boolean
OperationView. validatePreAggregationFilter(Element element)
Validates an element against the pre aggregation contained in the operation View. -
Uses of Element in uk.gov.gchq.gaffer.operation.impl
Methods in uk.gov.gchq.gaffer.operation.impl that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
CountGroups. getInput()
Iterable<? extends Element>
SampleElementsForSplitPoints. getInput()
Iterable<? extends Element>
Validate. getInput()
List<OperationChain<Iterable<Element>>>
GetWalks. getOperations()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
Validate. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.operation.impl with type arguments of type Element Modifier and Type Method Description void
GetWalks. addOperations(List<Output<Iterable<Element>>> operations)
GetWalks.Builder
GetWalks.Builder. addOperations(List<Output<Iterable<Element>>> operations)
GetWalks.Builder
GetWalks.Builder. operations(List<Output<Iterable<Element>>> operations)
void
CountGroups. setInput(Iterable<? extends Element> input)
void
SampleElementsForSplitPoints. setInput(Iterable<? extends Element> input)
void
Validate. setInput(Iterable<? extends Element> input)
void
GetWalks. setOperations(List<Output<Iterable<Element>>> operations)
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.add
Methods in uk.gov.gchq.gaffer.operation.impl.add that return types with arguments of type Element Modifier and Type Method Description Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>>
AddElementsFromFile. getElementGenerator()
Class<? extends Function<Iterable<?>,Iterable<? extends Element>>>
AddElementsFromKafka. getElementGenerator()
Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>>
AddElementsFromSocket. getElementGenerator()
Iterable<? extends Element>
AddElements. getInput()
Method parameters in uk.gov.gchq.gaffer.operation.impl.add with type arguments of type Element Modifier and Type Method Description AddElementsFromFile.Builder
AddElementsFromFile.Builder. generator(Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>> generator)
AddElementsFromKafka.Builder
AddElementsFromKafka.Builder. generator(Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>> generator)
AddElementsFromSocket.Builder
AddElementsFromSocket.Builder. generator(Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>> generator)
void
AddElementsFromFile. setElementGenerator(Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>> elementGenerator)
void
AddElementsFromKafka. setElementGenerator(Class<? extends Function<Iterable<?>,Iterable<? extends Element>>> elementGenerator)
void
AddElementsFromSocket. setElementGenerator(Class<? extends Function<Iterable<? extends String>,Iterable<? extends Element>>> elementGenerator)
void
AddElements. setInput(Iterable<? extends Element> elements)
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.compare
Methods in uk.gov.gchq.gaffer.operation.impl.compare that return types with arguments of type Element Modifier and Type Method Description default Comparator<Element>
ElementComparison. getCombinedComparator()
Combine all currently registered comparators into a singleComparator
object.List<Comparator<Element>>
ElementComparison. getComparators()
Get the list ofElement
comparators registered to the operation.List<Comparator<Element>>
Max. getComparators()
List<Comparator<Element>>
Min. getComparators()
List<Comparator<Element>>
Sort. getComparators()
Iterable<? extends Element>
Max. getInput()
Iterable<? extends Element>
Min. getInput()
Iterable<? extends Element>
Sort. getInput()
com.fasterxml.jackson.core.type.TypeReference<Element>
Max. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Element>
Min. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
Sort. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.operation.impl.compare with type arguments of type Element Modifier and Type Method Description Max.Builder
Max.Builder. comparators(List<Comparator<Element>> comparators)
Min.Builder
Min.Builder. comparators(List<Comparator<Element>> comparators)
Sort.Builder
Sort.Builder. comparators(List<Comparator<Element>> comparators)
void
Max. setComparators(List<Comparator<Element>> comparators)
void
Min. setComparators(List<Comparator<Element>> comparators)
void
Sort. setComparators(List<Comparator<Element>> comparators)
void
Max. setInput(Iterable<? extends Element> input)
void
Min. setInput(Iterable<? extends Element> input)
void
Sort. setInput(Iterable<? extends Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.delete
Methods in uk.gov.gchq.gaffer.operation.impl.delete that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
DeleteElements. getInput()
Method parameters in uk.gov.gchq.gaffer.operation.impl.delete with type arguments of type Element Modifier and Type Method Description void
DeleteElements. setInput(Iterable<? extends Element> elements)
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.function
Methods in uk.gov.gchq.gaffer.operation.impl.function that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
Aggregate. getInput()
Iterable<? extends Element>
Filter. getInput()
Iterable<? extends Element>
Transform. getInput()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
Aggregate. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
Filter. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
Transform. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.operation.impl.function with type arguments of type Element Modifier and Type Method Description void
Aggregate. setInput(Iterable<? extends Element> input)
void
Filter. setInput(Iterable<? extends Element> input)
void
Transform. setInput(Iterable<? extends Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.generate
Methods in uk.gov.gchq.gaffer.operation.impl.generate that return types with arguments of type Element Modifier and Type Method Description Function<Iterable<? extends OBJ>,Iterable<? extends Element>>
GenerateElements. getElementGenerator()
Function<Iterable<? extends Element>,Iterable<? extends OBJ>>
GenerateObjects. getElementGenerator()
Iterable<? extends Element>
GenerateObjects. getInput()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GenerateElements. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.operation.impl.generate with type arguments of type Element Modifier and Type Method Description GenerateElements.Builder<OBJ>
GenerateElements.Builder. generator(Function<Iterable<? extends OBJ>,Iterable<? extends Element>> generator)
GenerateObjects.Builder<OBJ>
GenerateObjects.Builder. generator(Function<Iterable<? extends Element>,Iterable<? extends OBJ>> generator)
void
GenerateObjects. setInput(Iterable<? extends Element> input)
Constructor parameters in uk.gov.gchq.gaffer.operation.impl.generate with type arguments of type Element Constructor Description GenerateElements(Function<Iterable<? extends OBJ>,Iterable<? extends Element>> elementGenerator)
GenerateObjects(Function<Iterable<? extends Element>,Iterable<? extends OBJ>> elementGenerator)
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.get
Methods in uk.gov.gchq.gaffer.operation.impl.get that return types with arguments of type Element Modifier and Type Method Description com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GetAllElements. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<Iterable<? extends Element>>
GetElements. getOutputTypeReference()
-
Uses of Element in uk.gov.gchq.gaffer.operation.impl.output
Methods in uk.gov.gchq.gaffer.operation.impl.output that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
ToCsv. getInput()
Iterable<? extends Element>
ToMap. getInput()
Method parameters in uk.gov.gchq.gaffer.operation.impl.output with type arguments of type Element Modifier and Type Method Description void
ToCsv. setInput(Iterable<? extends Element> input)
void
ToMap. setInput(Iterable<? extends Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.operation.util
Methods in uk.gov.gchq.gaffer.operation.util that return types with arguments of type Element Modifier and Type Method Description Stream<Element>
FilterStreamSupplier. get()
-
Uses of Element in uk.gov.gchq.gaffer.rest.example
Methods in uk.gov.gchq.gaffer.rest.example that return Element Modifier and Type Method Description Element
ExampleElementGenerator. _apply(ExampleDomainObject obj)
Methods in uk.gov.gchq.gaffer.rest.example with parameters of type Element Modifier and Type Method Description ExampleDomainObject
ExampleDomainObjectGenerator. _apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.rest.service.v1
Methods in uk.gov.gchq.gaffer.rest.service.v1 that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
IOperationService. generateElements(GenerateElements<Object> operation)
Iterable<Element>
OperationService. generateElements(GenerateElements<Object> operation)
Iterable<Element>
IOperationService. getAllElements(GetAllElements operation)
Iterable<Element>
OperationService. getAllElements(GetAllElements operation)
Iterable<Element>
IOperationService. getElements(GetElements operation)
Iterable<Element>
OperationService. getElements(GetElements operation)
Method parameters in uk.gov.gchq.gaffer.rest.service.v1 with type arguments of type Element Modifier and Type Method Description org.glassfish.jersey.server.ChunkedOutput<String>
IOperationService. executeChunkedChain(OperationChainDAO<Iterable<Element>> opChain)
-
Uses of Element in uk.gov.gchq.gaffer.sketches
Methods in uk.gov.gchq.gaffer.sketches that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
CardinalityEntityGenerator. _apply(Element element)
Methods in uk.gov.gchq.gaffer.sketches with parameters of type Element Modifier and Type Method Description Iterable<Element>
CardinalityEntityGenerator. _apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.spark.data.generator
Methods in uk.gov.gchq.gaffer.spark.data.generator that return Element Modifier and Type Method Description Element
RowToElementGenerator. _apply(org.apache.spark.sql.Row row)
Methods in uk.gov.gchq.gaffer.spark.data.generator that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
RowToElementGenerator. apply(Iterable<? extends org.apache.spark.sql.Row> rows)
-
Uses of Element in uk.gov.gchq.gaffer.spark.operation.dataframe
Fields in uk.gov.gchq.gaffer.spark.operation.dataframe with type parameters of type Element Modifier and Type Field Description static scala.reflect.ClassTag<Element>
ClassTagConstants. ELEMENT_CLASS_TAG
Methods in uk.gov.gchq.gaffer.spark.operation.dataframe that return types with arguments of type Element Modifier and Type Method Description Output<org.apache.spark.rdd.RDD<Element>>
FiltersToOperationConverter. getOperation()
Creates an operation to return an RDD in which as much filtering as possible has been carried out by Gaffer in Accumulo's tablet servers before the data is sent to a Spark executor.Methods in uk.gov.gchq.gaffer.spark.operation.dataframe with parameters of type Element Modifier and Type Method Description org.apache.spark.sql.Row
ConvertElementToRow. apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.spark.operation.javardd
Methods in uk.gov.gchq.gaffer.spark.operation.javardd that return types with arguments of type Element Modifier and Type Method Description org.apache.spark.api.java.JavaRDD<Element>
ImportJavaRDDOfElements. getInput()
org.apache.spark.api.java.JavaRDD<Element>
SplitStoreFromJavaRDDOfElements. getInput()
com.fasterxml.jackson.core.type.TypeReference<org.apache.spark.api.java.JavaRDD<Element>>
GetJavaRDDOfAllElements. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<org.apache.spark.api.java.JavaRDD<Element>>
GetJavaRDDOfElements. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.spark.operation.javardd with type arguments of type Element Modifier and Type Method Description void
ImportJavaRDDOfElements. setInput(org.apache.spark.api.java.JavaRDD<Element> input)
void
SplitStoreFromJavaRDDOfElements. setInput(org.apache.spark.api.java.JavaRDD<Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.spark.operation.scalardd
Methods in uk.gov.gchq.gaffer.spark.operation.scalardd that return types with arguments of type Element Modifier and Type Method Description org.apache.spark.rdd.RDD<Element>
ImportRDDOfElements. getInput()
org.apache.spark.rdd.RDD<Element>
SplitStoreFromRDDOfElements. getInput()
com.fasterxml.jackson.core.type.TypeReference<org.apache.spark.rdd.RDD<Element>>
GetRDDOfAllElements. getOutputTypeReference()
com.fasterxml.jackson.core.type.TypeReference<org.apache.spark.rdd.RDD<Element>>
GetRDDOfElements. getOutputTypeReference()
Method parameters in uk.gov.gchq.gaffer.spark.operation.scalardd with type arguments of type Element Modifier and Type Method Description void
ImportRDDOfElements. setInput(org.apache.spark.rdd.RDD<Element> input)
void
SplitStoreFromRDDOfElements. setInput(org.apache.spark.rdd.RDD<Element> input)
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler that return Element Modifier and Type Method Description Element
AbstractGetRDDHandler.FirstElement. apply(scala.Tuple2<Element,org.apache.hadoop.io.NullWritable> tuple)
Method parameters in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler with type arguments of type Element Modifier and Type Method Description Element
AbstractGetRDDHandler.FirstElement. apply(scala.Tuple2<Element,org.apache.hadoop.io.NullWritable> tuple)
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd that return types with arguments of type Element 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)
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd that return Element Modifier and Type Method Description Element
GetRDDOfAllElementsHandler.EntryToElement. apply(Map.Entry<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Value> entry)
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd that return types with arguments of type Element Modifier and Type Method Description scala.collection.Iterator<Element>
GetRDDOfAllElementsHandler.EntryIteratorToElementIterator. apply(scala.collection.Iterator<Map.Entry<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Value>> entryIterator)
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)
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd with parameters of type Element Modifier and Type Method Description Object
GetRDDOfAllElementsHandler.FilterOutNull. apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.javardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.javardd that return types with arguments of type Element Modifier and Type Method Description com.fasterxml.jackson.core.type.TypeReference<org.apache.spark.api.java.JavaRDD<Element>>
GetJavaRDDOfElementsInRanges. getOutputTypeReference()
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.scalardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.scalardd that return types with arguments of type Element Modifier and Type Method Description com.fasterxml.jackson.core.type.TypeReference<org.apache.spark.rdd.RDD<Element>>
GetRDDOfElementsInRanges. getOutputTypeReference()
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils.java
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils.java with parameters of type Element Modifier and Type Method Description Iterator<scala.Tuple2<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Value>>
ElementConverterFunction. call(Element e)
-
Uses of Element in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils.scala
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils.scala with parameters of type Element Modifier and Type Method Description scala.collection.TraversableOnce<scala.Tuple2<org.apache.accumulo.core.data.Key,org.apache.accumulo.core.data.Value>>
ElementConverterFunction. apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.store
Methods in uk.gov.gchq.gaffer.store that return Element Modifier and Type Method Description Element
Store. populateElement(Element lazyElement)
Ensures all identifier and property values are populated on an element by triggering getters on the element for all identifier and properties in theSchema
forcing a lazy element to load all of its values.Methods in uk.gov.gchq.gaffer.store with parameters of type Element Modifier and Type Method Description Element
Store. populateElement(Element lazyElement)
Ensures all identifier and property values are populated on an element by triggering getters on the element for all identifier and properties in theSchema
forcing a lazy element to load all of its values.boolean
ElementValidator. validate(Element element)
boolean
ElementValidator. validateAggregation(Element element)
boolean
ElementValidator. validateInput(Element element)
boolean
ElementValidator. validateTransform(Element element)
boolean
ElementValidator. validateWithSchema(Element element)
uk.gov.gchq.koryphe.ValidationResult
ElementValidator. validateWithValidationResult(Element element)
Constructor parameters in uk.gov.gchq.gaffer.store with type arguments of type Element Constructor Description ValidatedElements(Iterable<? extends Element> elements, View view, boolean skipInvalid)
ValidatedElements(Iterable<? extends Element> elements, Schema schema, boolean skipInvalid)
-
Uses of Element in uk.gov.gchq.gaffer.store.element
Methods in uk.gov.gchq.gaffer.store.element with parameters of type Element Modifier and Type Method Description static ElementKey
ElementKey. create(Element element, Set<String> groupBy)
static ElementKey
ElementKey. create(Element element, Schema schema)
static ElementKey
ElementKey. create(Element element, SchemaElementDefinition elementDef)
-
Uses of Element in uk.gov.gchq.gaffer.store.operation.handler
Methods in uk.gov.gchq.gaffer.store.operation.handler that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
ValidateHandler. doOperation(Validate operation, Context context, Store store)
Iterable<? extends Element>
ValidateHandler. doOperation(Validate operation, Schema schema)
-
Uses of Element in uk.gov.gchq.gaffer.store.operation.handler.compare
Methods in uk.gov.gchq.gaffer.store.operation.handler.compare that return Element Modifier and Type Method Description Element
MaxHandler. doOperation(Max operation, Context context, Store store)
Element
MinHandler. doOperation(Min operation, Context context, Store store)
Methods in uk.gov.gchq.gaffer.store.operation.handler.compare that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
SortHandler. doOperation(Sort operation, Context context, Store store)
-
Uses of Element in uk.gov.gchq.gaffer.store.operation.handler.function
Methods in uk.gov.gchq.gaffer.store.operation.handler.function that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
AggregateHandler. doOperation(Aggregate operation, Context context, Store store)
Iterable<? extends Element>
AggregateHandler. doOperation(Aggregate operation, Schema schema)
Iterable<? extends Element>
FilterHandler. doOperation(Filter operation, Context context, Store store)
Iterable<? extends Element>
FilterHandler. doOperation(Filter operation, Schema schema)
Iterable<? extends Element>
TransformHandler. doOperation(Transform operation, Context context, Store store)
Iterable<? extends Element>
TransformHandler. doOperation(Transform operation, Schema schema)
-
Uses of Element in uk.gov.gchq.gaffer.store.operation.handler.generate
Methods in uk.gov.gchq.gaffer.store.operation.handler.generate that return types with arguments of type Element Modifier and Type Method Description Iterable<? extends Element>
GenerateElementsHandler. doOperation(GenerateElements<OBJ> operation, Context context, Store store)
-
Uses of Element in uk.gov.gchq.gaffer.store.operation.util
Methods in uk.gov.gchq.gaffer.store.operation.util that return types with arguments of type Element Modifier and Type Method Description Stream<Element>
TransformStreamSupplier. get()
-
Uses of Element in uk.gov.gchq.gaffer.store.serialiser
Methods in uk.gov.gchq.gaffer.store.serialiser that return Element Modifier and Type Method Description Element
ElementSerialiser. deserialise(byte[] bytes)
Element
ElementSerialiser. deserialiseEmpty()
Methods in uk.gov.gchq.gaffer.store.serialiser with parameters of type Element Modifier and Type Method Description byte[]
ElementSerialiser. serialise(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.store.util
Methods in uk.gov.gchq.gaffer.store.util that return Element Modifier and Type Method Description Element
AggregatorUtil.ToElementKey. apply(Element element)
Methods in uk.gov.gchq.gaffer.store.util that return types with arguments of type Element Modifier and Type Method Description static Iterable<Element>
AggregatorUtil. ingestAggregate(Iterable<? extends Element> elements, Schema schema)
Applies ingest aggregation to the provided iterable ofElement
s.static Iterable<Element>
AggregatorUtil. queryAggregate(Iterable<? extends Element> elements, Schema schema, View view)
Applies query time aggregation to the provided iterable ofElement
s.static Iterable<Element>
AggregatorUtil. queryAggregate(Iterable<? extends Element> elements, Schema schema, View view, boolean includeMatchedVertex)
Applies query time aggregation to the provided iterable ofElement
s.Methods in uk.gov.gchq.gaffer.store.util with parameters of type Element Modifier and Type Method Description Element
AggregatorUtil.ToElementKey. apply(Element element)
boolean
AggregatorUtil.IsElementAggregated. test(Element element)
Method parameters in uk.gov.gchq.gaffer.store.util with type arguments of type Element Modifier and Type Method Description static Iterable<Element>
AggregatorUtil. ingestAggregate(Iterable<? extends Element> elements, Schema schema)
Applies ingest aggregation to the provided iterable ofElement
s.static Iterable<Element>
AggregatorUtil. queryAggregate(Iterable<? extends Element> elements, Schema schema, View view)
Applies query time aggregation to the provided iterable ofElement
s.static Iterable<Element>
AggregatorUtil. queryAggregate(Iterable<? extends Element> elements, Schema schema, View view, boolean includeMatchedVertex)
Applies query time aggregation to the provided iterable ofElement
s. -
Uses of Element in uk.gov.gchq.gaffer.tinkerpop.generator
Methods in uk.gov.gchq.gaffer.tinkerpop.generator with parameters of type Element Modifier and Type Method Description GafferPopEdge
GafferPopEdgeGenerator. _apply(Element element)
GafferPopElement
GafferPopElementGenerator. _apply(Element element)
GafferPopVertex
GafferPopVertexGenerator. _apply(Element element)
-
Uses of Element in uk.gov.gchq.gaffer.tinkerpop.process.traversal.util
Method parameters in uk.gov.gchq.gaffer.tinkerpop.process.traversal.util with type arguments of type Element Modifier and Type Method Description static Iterable<org.apache.tinkerpop.gremlin.structure.Vertex>
GafferVertexUtils. getOrphanVertices(Iterable<? extends Element> result, GafferPopGraph graph, Object... vertexIds)
Util method to extract vertices that are vertices on an edge but do not have an associatedVertex
orEntity
the current graph. -
Uses of Element in uk.gov.gchq.gaffer.traffic.generator
Methods in uk.gov.gchq.gaffer.traffic.generator that return types with arguments of type Element Modifier and Type Method Description Iterable<Element>
RoadTrafficCsvElementGenerator. _apply(org.apache.commons.csv.CSVRecord record)
Iterable<Element>
RoadTrafficStringElementGenerator. _apply(String line)
-