Modifier and Type | Class and Description |
---|---|
class |
RuntimeSerializerFactory<T> |
Modifier and Type | Method and Description |
---|---|
TypeSerializerFactory<?> |
Channel.getSerializer()
Gets the serializer from this Channel.
|
TypeSerializerFactory<?> |
SourcePlanNode.getSerializer()
Gets the serializer from this PlanNode.
|
TypeSerializerFactory<?> |
BulkIterationPlanNode.getSerializerForIterationChannel() |
TypeSerializerFactory<?> |
WorksetIterationPlanNode.getSerializerForIterationChannel() |
TypeSerializerFactory<?> |
WorksetIterationPlanNode.getSolutionSetSerializer() |
TypeSerializerFactory<?> |
WorksetIterationPlanNode.getWorksetSerializer() |
Modifier and Type | Method and Description |
---|---|
void |
Channel.setSerializer(TypeSerializerFactory<?> serializer)
Sets the serializer for this Channel.
|
void |
SourcePlanNode.setSerializer(TypeSerializerFactory<?> serializer)
Sets the serializer for this PlanNode.
|
void |
BulkIterationPlanNode.setSerializerForIterationChannel(TypeSerializerFactory<?> serializerForIterationChannel) |
void |
WorksetIterationPlanNode.setSerializerForIterationChannel(TypeSerializerFactory<?> serializerForIterationChannel) |
void |
WorksetIterationPlanNode.setSolutionSetSerializer(TypeSerializerFactory<?> solutionSetSerializer) |
void |
WorksetIterationPlanNode.setWorksetSerializer(TypeSerializerFactory<?> worksetSerializer) |
Modifier and Type | Method and Description |
---|---|
<T> BroadcastVariableMaterialization<T,?> |
BroadcastVariableManager.materializeBroadcastVariable(String name,
int superstep,
BatchTask<?,?> holder,
MutableReader<?> reader,
TypeSerializerFactory<T> serializerFactory)
Materializes the broadcast variable for the given name, scoped to the given task and its iteration superstep.
|
void |
BroadcastVariableMaterialization.materializeVariable(MutableReader<?> reader,
TypeSerializerFactory<?> serializerFactory,
BatchTask<?,?> referenceHolder) |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializerFactory<?>[] |
BatchTask.broadcastInputSerializers
The serializers for the broadcast input data types.
|
protected TypeSerializerFactory<?>[] |
BatchTask.inputSerializers
The serializers for the input data type.
|
Modifier and Type | Method and Description |
---|---|
<X> TypeSerializerFactory<X> |
BatchTask.getInputSerializer(int index) |
<X> TypeSerializerFactory<X> |
TaskContext.getInputSerializer(int index) |
Modifier and Type | Method and Description |
---|---|
protected MutableObjectIterator<?> |
BatchTask.createInputIterator(MutableReader<?> inputReader,
TypeSerializerFactory<?> serializerFactory) |
Constructor and Description |
---|
TempBarrier(AbstractInvokable owner,
MutableObjectIterator<T> input,
TypeSerializerFactory<T> serializerFactory,
MemoryManager memManager,
IOManager ioManager,
int numPages) |
Modifier and Type | Method and Description |
---|---|
protected UnilateralSortMerger.ThreadBase<E> |
UnilateralSortMerger.getSpillingThread(ExceptionHandler<IOException> exceptionHandler,
UnilateralSortMerger.CircularQueues<E> queues,
AbstractInvokable parentTask,
MemoryManager memoryManager,
IOManager ioManager,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
List<MemorySegment> sortReadMemory,
List<MemorySegment> writeMemory,
int maxFileHandles) |
protected UnilateralSortMerger.ThreadBase<E> |
CombiningUnilateralSortMerger.getSpillingThread(ExceptionHandler<IOException> exceptionHandler,
UnilateralSortMerger.CircularQueues<E> queues,
AbstractInvokable parentTask,
MemoryManager memoryManager,
IOManager ioManager,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
List<MemorySegment> sortReadMemory,
List<MemorySegment> writeMemory,
int maxFileHandles) |
Constructor and Description |
---|
CombiningUnilateralSortMerger(GroupCombineFunction<E,E> combineStub,
MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled)
Creates a new sorter that reads the data from a given reader and provides an iterator returning that
data in a sorted manner.
|
CombiningUnilateralSortMerger(GroupCombineFunction<E,E> combineStub,
MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled)
Creates a new sorter that reads the data from a given reader and provides an iterator returning that
data in a sorted manner.
|
UnilateralSortMerger(MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled) |
UnilateralSortMerger(MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled) |
UnilateralSortMerger(MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean noSpillingMemory,
boolean handleLargeRecords,
boolean objectReuseEnabled) |
UnilateralSortMerger(MemoryManager memoryManager,
List<MemorySegment> memory,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled) |
UnilateralSortMerger(MemoryManager memoryManager,
List<MemorySegment> memory,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean noSpillingMemory,
boolean handleLargeRecords,
boolean objectReuseEnabled) |
UnilateralSortMerger(MemoryManager memoryManager,
List<MemorySegment> memory,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean noSpillingMemory,
boolean handleLargeRecords,
boolean objectReuseEnabled,
InMemorySorterFactory<E> inMemorySorterFactory) |
Modifier and Type | Method and Description |
---|---|
<T> TypeSerializerFactory<T> |
TaskConfig.getBroadcastInputSerializer(int inputNum,
ClassLoader cl) |
<T> TypeSerializerFactory<T> |
TaskConfig.getInputSerializer(int inputNum,
ClassLoader cl) |
<T> TypeSerializerFactory<T> |
TaskConfig.getOutputSerializer(ClassLoader cl) |
<T> TypeSerializerFactory<T> |
TaskConfig.getSolutionSetSerializer(ClassLoader cl) |
Modifier and Type | Method and Description |
---|---|
void |
TaskConfig.setBroadcastInputSerializer(TypeSerializerFactory<?> factory,
int inputNum) |
void |
TaskConfig.setInputSerializer(TypeSerializerFactory<?> factory,
int inputNum) |
void |
TaskConfig.setOutputSerializer(TypeSerializerFactory<?> factory) |
void |
TaskConfig.setSolutionSetSerializer(TypeSerializerFactory<?> factory) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.