sanha commented on a change in pull request #2: [NEMO-7] Intra-TaskGroup 
pipelining
URL: https://github.com/apache/incubator-nemo/pull/2#discussion_r175277609
 
 

 ##########
 File path: 
runtime/executor/src/main/java/edu/snu/nemo/runtime/executor/TaskGroupExecutor.java
 ##########
 @@ -145,303 +212,407 @@ private void initializeDataTransfer() {
         .collect(Collectors.toSet());
   }
 
-  // Helper functions to initializes stage-internal edges.
-  private void createLocalReader(final Task task, final RuntimeEdge<Task> 
internalEdge) {
-    final InputReader inputReader = 
channelFactory.createLocalReader(taskGroupIdx, internalEdge);
-    addInputReader(task, inputReader);
-  }
-
-  private void createLocalWriter(final Task task, final RuntimeEdge<Task> 
internalEdge) {
-    final OutputWriter outputWriter = channelFactory.createLocalWriter(task, 
taskGroupIdx, internalEdge);
-    addOutputWriter(task, outputWriter);
-  }
-
-  // Helper functions to add the initialized reader/writer to the maintained 
map.
-  private void addInputReader(final Task task, final InputReader inputReader) {
+  /**
+   * Add input OutputCollectors to each {@link Task}.
+   * Input OutputCollector denotes all the OutputCollectors of intra-Stage 
parent tasks of this task.
+   *
+   * @param task the Task to add input OutputCollectors to.
+   */
+  private void addInputFromThisStage(final Task task, final TaskDataHandler 
dataHandler) {
+    List<Task> parentTasks = taskGroupDag.getParents(task.getId());
     final String physicalTaskId = getPhysicalTaskId(task.getId());
-    physicalTaskIdToInputReaderMap.computeIfAbsent(physicalTaskId, readerList 
-> new ArrayList<>());
-    physicalTaskIdToInputReaderMap.get(physicalTaskId).add(inputReader);
-  }
 
-  private void addOutputWriter(final Task task, final OutputWriter 
outputWriter) {
-    final String physicalTaskId = getPhysicalTaskId(task.getId());
-    physicalTaskIdToOutputWriterMap.computeIfAbsent(physicalTaskId, readerList 
-> new ArrayList<>());
-    physicalTaskIdToOutputWriterMap.get(physicalTaskId).add(outputWriter);
+    if (parentTasks != null) {
+      parentTasks.forEach(parent -> {
+        final OutputCollectorImpl parentOutputCollector = 
getTaskDataHandler(parent).getOutputCollector();
+        if (parentOutputCollector.hasSideInputFor(physicalTaskId)) {
+          dataHandler.addSideInputFromThisStage(parentOutputCollector);
+        } else {
+          dataHandler.addInputFromThisStages(parentOutputCollector);
+        }
+      });
+    }
   }
 
   /**
-   * Executes the task group.
+   * Add output outputCollectors to each {@link Task}.
+   * Output outputCollector denotes the one and only one outputCollector of 
this task.
+   * Check the outgoing edges that will use this outputCollector,
+   * and set this outputCollector as side input if any one of the edges uses 
this outputCollector as side input.
+   *
+   * @param task the Task to add output outputCollectors to.
    */
-  public void execute() {
-    LOG.info("{} Execution Started!", taskGroupId);
-    if (isExecutionRequested) {
-      throw new RuntimeException("TaskGroup {" + taskGroupId + "} execution 
called again!");
-    } else {
-      isExecutionRequested = true;
-    }
-
-    taskGroupStateManager.onTaskGroupStateChanged(
-        TaskGroupState.State.EXECUTING, Optional.empty(), Optional.empty());
+  private void setOutputCollector(final Task task, final TaskDataHandler 
dataHandler) {
+    final OutputCollectorImpl outputCollector = new OutputCollectorImpl();
+    final String physicalTaskId = getPhysicalTaskId(task.getId());
 
-    taskGroupDag.topologicalDo(task -> {
-      final String physicalTaskId = getPhysicalTaskId(task.getId());
-      taskGroupStateManager.onTaskStateChanged(physicalTaskId, 
TaskState.State.EXECUTING, Optional.empty());
-      try {
-        if (task instanceof BoundedSourceTask) {
-          launchBoundedSourceTask((BoundedSourceTask) task);
-          taskGroupStateManager.onTaskStateChanged(physicalTaskId, 
TaskState.State.COMPLETE, Optional.empty());
-          LOG.info("{} Execution Complete!", taskGroupId);
-        } else if (task instanceof OperatorTask) {
-          launchOperatorTask((OperatorTask) task);
-          taskGroupStateManager.onTaskStateChanged(physicalTaskId, 
TaskState.State.COMPLETE, Optional.empty());
-          LOG.info("{} Execution Complete!", taskGroupId);
-        } else if (task instanceof MetricCollectionBarrierTask) {
-          launchMetricCollectionBarrierTask((MetricCollectionBarrierTask) 
task);
-          taskGroupStateManager.onTaskStateChanged(physicalTaskId, 
TaskState.State.ON_HOLD, Optional.empty());
-          LOG.info("{} Execution Complete!", taskGroupId);
-        } else {
-          throw new UnsupportedOperationException(task.toString());
-        }
-      } catch (final BlockFetchException ex) {
-        taskGroupStateManager.onTaskStateChanged(physicalTaskId, 
TaskState.State.FAILED_RECOVERABLE,
-            
Optional.of(TaskGroupState.RecoverableFailureCause.INPUT_READ_FAILURE));
-        LOG.warn("{} Execution Failed (Recoverable)! Exception: {}",
-            new Object[] {taskGroupId, ex.toString()});
-      } catch (final BlockWriteException ex2) {
-        taskGroupStateManager.onTaskStateChanged(physicalTaskId, 
TaskState.State.FAILED_RECOVERABLE,
-            
Optional.of(TaskGroupState.RecoverableFailureCause.OUTPUT_WRITE_FAILURE));
-        LOG.warn("{} Execution Failed (Recoverable)! Exception: {}",
-            new Object[] {taskGroupId, ex2.toString()});
-      } catch (final Exception e) {
-        taskGroupStateManager.onTaskStateChanged(
-            physicalTaskId, TaskState.State.FAILED_UNRECOVERABLE, 
Optional.empty());
-        throw new RuntimeException(e);
+    taskGroupDag.getOutgoingEdgesOf(task).forEach(outEdge -> {
+      if (outEdge.isSideInput()) {
+        outputCollector.setSideInputRuntimeEdge(outEdge);
+        outputCollector.setAsSideInputFor(physicalTaskId);
       }
     });
+
+    dataHandler.setOutputCollector(outputCollector);
   }
 
-  /**
-   * Processes a BoundedSourceTask.
-   *
-   * @param boundedSourceTask the bounded source task to execute
-   * @throws Exception occurred during input read.
-   */
-  private void launchBoundedSourceTask(final BoundedSourceTask 
boundedSourceTask) throws Exception {
-    final String physicalTaskId = getPhysicalTaskId(boundedSourceTask.getId());
-    final Map<String, Object> metric = new HashMap<>();
-    metricCollector.beginMeasurement(physicalTaskId, metric);
+  private boolean hasOutputWriter(final Task task) {
+    return !getTaskDataHandler(task).getOutputWriters().isEmpty();
+  }
 
-    final long readStartTime = System.currentTimeMillis();
-    final Readable readable = boundedSourceTask.getReadable();
-    final Iterable readData = readable.read();
-    final long readEndTime = System.currentTimeMillis();
-    metric.put("BoundedSourceReadTime(ms)", readEndTime - readStartTime);
+  private void setTaskPutOnHold(final MetricCollectionBarrierTask task) {
+    final String physicalTaskId = getPhysicalTaskId(task.getId());
+    logicalTaskIdPutOnHold = 
RuntimeIdGenerator.getLogicalTaskIdIdFromPhysicalTaskId(physicalTaskId);
+  }
 
+  private void writeAndCloseOutputWriters(final Task task) {
+    final String physicalTaskId = getPhysicalTaskId(task.getId());
     final List<Long> writtenBytesList = new ArrayList<>();
-    for (final OutputWriter outputWriter : 
physicalTaskIdToOutputWriterMap.get(physicalTaskId)) {
-      outputWriter.write(readData);
+    final Map<String, Object> metric = new HashMap<>();
+    metricCollector.beginMeasurement(physicalTaskId, metric);
+    final long writeStartTime = System.currentTimeMillis();
+
+    getTaskDataHandler(task).getOutputWriters().forEach(outputWriter -> {
+      outputWriter.write();
       outputWriter.close();
       final Optional<Long> writtenBytes = outputWriter.getWrittenBytes();
       writtenBytes.ifPresent(writtenBytesList::add);
-    }
+    });
+
     final long writeEndTime = System.currentTimeMillis();
-    metric.put("OutputWriteTime(ms)", writeEndTime - readEndTime);
+    metric.put("OutputWriteTime(ms)", writeEndTime - writeStartTime);
     putWrittenBytesMetric(writtenBytesList, metric);
     metricCollector.endMeasurement(physicalTaskId, metric);
   }
 
-  /**
-   * Processes an OperatorTask.
-   * @param operatorTask to execute
-   */
-  private void launchOperatorTask(final OperatorTask operatorTask) {
-    final Map<Transform, Object> sideInputMap = new HashMap<>();
-    final List<DataUtil.IteratorWithNumBytes> sideInputIterators = new 
ArrayList<>();
-    final String physicalTaskId = getPhysicalTaskId(operatorTask.getId());
+  private void prepareInputFromSource() {
+    taskGroupDag.topologicalDo(task -> {
+      if (task instanceof BoundedSourceTask) {
+        try {
+          final String iteratorId = generateIteratorId();
+          final Iterator iterator = ((BoundedSourceTask) 
task).getReadable().read().iterator();
+          idToSrcIteratorMap.putIfAbsent(iteratorId, iterator);
+          srcIteratorIdToDataHandlersMap.putIfAbsent(iteratorId, new 
ArrayList<>());
+          
srcIteratorIdToDataHandlersMap.get(iteratorId).add(getTaskDataHandler(task));
+        } catch (final BlockFetchException ex) {
+          
taskGroupStateManager.onTaskGroupStateChanged(TaskGroupState.State.FAILED_RECOVERABLE,
+              Optional.empty(), 
Optional.of(TaskGroupState.RecoverableFailureCause.INPUT_READ_FAILURE));
+          LOG.info("{} Execution Failed (Recoverable: input read failure)! 
Exception: {}",
+              taskGroupId, ex.toString());
+        } catch (final Exception e) {
+          
taskGroupStateManager.onTaskGroupStateChanged(TaskGroupState.State.FAILED_UNRECOVERABLE,
+              Optional.empty(), Optional.empty());
+          LOG.info("{} Execution Failed! Exception: {}", taskGroupId, 
e.toString());
+          throw new RuntimeException(e);
+        }
+      }
+      // TODO #XXX: Support other types of source tasks, i. e. 
InitializedSourceTask
+    });
+  }
 
-    final Map<String, Object> metric = new HashMap<>();
-    metricCollector.beginMeasurement(physicalTaskId, metric);
-    long accumulatedBlockedReadTime = 0;
-    long accumulatedWriteTime = 0;
-    long accumulatedSerializedBlockSize = 0;
-    long accumulatedEncodedBlockSize = 0;
-    boolean blockSizeAvailable = true;
-
-    final long readStartTime = System.currentTimeMillis();
-    // Check for side inputs
-    
physicalTaskIdToInputReaderMap.get(physicalTaskId).stream().filter(InputReader::isSideInputReader)
-        .forEach(inputReader -> {
+  private void prepareInputFromOtherStages() {
+    inputReaderToDataHandlersMap.forEach((inputReader, dataHandlers) -> {
+      final List<CompletableFuture<DataUtil.IteratorWithNumBytes>> futures = 
inputReader.read();
+      numPartitions += futures.size();
+
+      // Add consumers which will push iterator when the futures are complete.
+      futures.forEach(compFuture -> compFuture.whenComplete((iterator, 
exception) -> {
+        if (exception != null) {
+          throw new BlockFetchException(exception);
+        }
+
+        final String iteratorId = generateIteratorId();
+        if (iteratorIdToDataHandlersMap.containsKey(iteratorId)) {
+          throw new RuntimeException("iteratorIdToDataHandlersMap already 
contains " + iteratorId);
+        } else {
+          iteratorIdToDataHandlersMap.computeIfAbsent(iteratorId, 
absentIteratorId -> dataHandlers);
           try {
-            if (!inputReader.isSideInputReader()) {
-              // Trying to get sideInput from a reader that does not handle 
sideInput.
-              // This is probably a bug. We're not trying to recover but 
ensure a hard fail.
-              throw new RuntimeException("Trying to get sideInput from 
non-sideInput reader");
-            }
-            final DataUtil.IteratorWithNumBytes sideInputIterator = 
inputReader.read().get(0).get();
-            final Object sideInput = getSideInput(sideInputIterator);
-
-            final RuntimeEdge inEdge = inputReader.getRuntimeEdge();
-            final Transform srcTransform;
-            if (inEdge instanceof PhysicalStageEdge) {
-              srcTransform = ((OperatorVertex) ((PhysicalStageEdge) 
inEdge).getSrcVertex())
-                  .getTransform();
-            } else {
-              srcTransform = ((OperatorTask) inEdge.getSrc()).getTransform();
-            }
-            sideInputMap.put(srcTransform, sideInput);
-            sideInputIterators.add(sideInputIterator);
-          } catch (final InterruptedException | ExecutionException e) {
-            throw new BlockFetchException(e);
+            partitionQueue.put(Pair.of(iteratorId, iterator));
+          } catch (InterruptedException e) {
+            throw new RuntimeException("Interrupted while receiving iterator " 
+ e);
           }
-        });
+        }
+      }));
+    });
+  }
 
-    for (final DataUtil.IteratorWithNumBytes iterator : sideInputIterators) {
-      try {
-        accumulatedSerializedBlockSize += iterator.getNumSerializedBytes();
-        accumulatedEncodedBlockSize += iterator.getNumEncodedBytes();
-      } catch (final 
DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException e) {
-        blockSizeAvailable = false;
-        break;
-      }
-    }
+  private boolean finishedAllTasks() {
+    // Total number of Tasks in this TaskGroup
+    int taskNum = taskDataHandlers.size();
+    int finishedTaskNum = finishedTaskIds.size();
 
-    final Transform.Context transformContext = new ContextImpl(sideInputMap);
-    final OutputCollectorImpl outputCollector = new OutputCollectorImpl();
+    return finishedTaskNum == taskNum;
+  }
 
-    final Transform transform = operatorTask.getTransform();
-    transform.prepare(transformContext, outputCollector);
-
-    // Check for non-side inputs
-    // This blocking queue contains the pairs having data and source vertex 
ids.
-    final BlockingQueue<Pair<DataUtil.IteratorWithNumBytes, String>> dataQueue 
= new LinkedBlockingQueue<>();
-    final AtomicInteger sourceParallelism = new AtomicInteger(0);
-    
physicalTaskIdToInputReaderMap.get(physicalTaskId).stream().filter(inputReader 
-> !inputReader.isSideInputReader())
-        .forEach(inputReader -> {
-          final List<CompletableFuture<DataUtil.IteratorWithNumBytes>> futures 
= inputReader.read();
-          final String srcIrVtxId = inputReader.getSrcIrVertexId();
-          sourceParallelism.getAndAdd(inputReader.getSourceParallelism());
-          // Add consumers which will push the data to the data queue when it 
ready to the futures.
-          futures.forEach(compFuture -> compFuture.whenComplete((data, 
exception) -> {
-            if (exception != null) {
-              throw new BlockFetchException(exception);
-            }
-            dataQueue.add(Pair.of(data, srcIrVtxId));
-          }));
-        });
-    final long readFutureEndTime = System.currentTimeMillis();
-    // Consumes all of the partitions from incoming edges.
-    for (int srcTaskNum = 0; srcTaskNum < sourceParallelism.get(); 
srcTaskNum++) {
+  private void initializeOutputToChildrenDataHandlersMap() {
+    srcIteratorIdToDataHandlersMap.values().forEach(dataHandlers ->
+        dataHandlers.forEach(dataHandler -> {
+          
outputToChildrenDataHandlersMap.putIfAbsent(dataHandler.getOutputCollector(), 
dataHandler.getChildren());
+        }));
+    iteratorIdToDataHandlersMap.values().forEach(dataHandlers ->
+        dataHandlers.forEach(dataHandler -> {
+          
outputToChildrenDataHandlersMap.putIfAbsent(dataHandler.getOutputCollector(), 
dataHandler.getChildren());
+        }));
+  }
+
+  private void updateOutputToChildrenDataHandlersMap() {
+    Map<OutputCollectorImpl, List<TaskDataHandler>> currentMap = 
outputToChildrenDataHandlersMap;
+    Map<OutputCollectorImpl, List<TaskDataHandler>> updatedMap = new 
HashMap<>();
+
+    currentMap.values().forEach(dataHandlers ->
+        dataHandlers.forEach(dataHandler -> {
+          updatedMap.putIfAbsent(dataHandler.getOutputCollector(), 
dataHandler.getChildren());
+        })
+    );
+
+    outputToChildrenDataHandlersMap = updatedMap;
+  }
+
+  private void closeTransform(final Task task) {
+    if (task instanceof OperatorTask) {
+      Transform transform = ((OperatorTask) task).getTransform();
+      transform.close();
+    }
+  }
+
+  private void sideInputFromOtherStages(final Task task, final Map<Transform, 
Object> sideInputMap) {
+    
getTaskDataHandler(task).getSideInputFromOtherStages().forEach(sideInputReader 
-> {
       try {
-        // Because the data queue is a blocking queue, we may need to wait 
some available data to be pushed.
-        final long blockedReadStartTime = System.currentTimeMillis();
-        final Pair<DataUtil.IteratorWithNumBytes, String> availableData = 
dataQueue.take();
-        final long blockedReadEndTime = System.currentTimeMillis();
-        accumulatedBlockedReadTime += blockedReadEndTime - 
blockedReadStartTime;
-        transform.onData(availableData.left(), availableData.right());
-        if (blockSizeAvailable) {
-          try {
-            accumulatedSerializedBlockSize += 
availableData.left().getNumSerializedBytes();
-            accumulatedEncodedBlockSize += 
availableData.left().getNumEncodedBytes();
-          } catch (final 
DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException e) {
-            blockSizeAvailable = false;
-          }
+        final DataUtil.IteratorWithNumBytes sideInputIterator = 
sideInputReader.read().get(0).get();
+        final Object sideInput = getSideInput(sideInputIterator);
+        final RuntimeEdge inEdge = sideInputReader.getRuntimeEdge();
+        final Transform srcTransform;
+        if (inEdge instanceof PhysicalStageEdge) {
+          srcTransform = ((OperatorVertex) ((PhysicalStageEdge) 
inEdge).getSrcVertex()).getTransform();
+        } else {
+          srcTransform = ((OperatorTask) inEdge.getSrc()).getTransform();
+        }
+        sideInputMap.put(srcTransform, sideInput);
+
+        // Collect metrics on block size if possible.
+        try {
+          serBlockSize += sideInputIterator.getNumSerializedBytes();
+        } catch (final 
DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException e) {
+          serBlockSize = -1;
         }
-      } catch (final InterruptedException e) {
+        try {
+          encodedBlockSize += sideInputIterator.getNumEncodedBytes();
+        } catch (final 
DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException e) {
+          encodedBlockSize = -1;
+        }
+      } catch (final InterruptedException | ExecutionException e) {
         throw new BlockFetchException(e);
       }
+    });
+  }
+
+  private void sideInputFromThisStage(final Task task, final Map<Transform, 
Object> sideInputMap) {
+    final String physicalTaskId = getPhysicalTaskId(task.getId());
+    getTaskDataHandler(task).getSideInputFromThisStage().forEach(input -> {
+      // because sideInput is only 1 element in the outputCollector
+      Object sideInput = input.remove();
+      final RuntimeEdge inEdge = input.getSideInputRuntimeEdge();
+      final Transform srcTransform;
+      if (inEdge instanceof PhysicalStageEdge) {
+        srcTransform = ((OperatorVertex) ((PhysicalStageEdge) 
inEdge).getSrcVertex()).getTransform();
+      } else {
+        srcTransform = ((OperatorTask) inEdge.getSrc()).getTransform();
+      }
+      sideInputMap.put(srcTransform, sideInput);
+    });
+  }
 
-      // Check whether there is any output data from the transform and write 
the output of this task to the writer.
-      final List output = outputCollector.collectOutputList();
-      if (!output.isEmpty() && 
physicalTaskIdToOutputWriterMap.containsKey(physicalTaskId)) {
-        final long writeStartTime = System.currentTimeMillis();
-        
physicalTaskIdToOutputWriterMap.get(physicalTaskId).forEach(outputWriter -> 
outputWriter.write(output));
-        final long writeEndTime = System.currentTimeMillis();
-        accumulatedWriteTime += writeEndTime - writeStartTime;
-      } // If else, this is a sink task.
+  /**
+   * Executes the task group.
+   */
+  public void execute() {
+    final Map<String, Object> metric = new HashMap<>();
+    metricCollector.beginMeasurement(taskGroupId, metric);
+    long boundedSrcReadStartTime = 0;
+    long boundedSrcReadEndTime = 0;
+    long inputReadStartTime = 0;
+    long inputReadEndTime = 0;
+    if (isExecutionRequested) {
+      throw new RuntimeException("TaskGroup {" + taskGroupId + "} execution 
called again!");
+    } else {
+      isExecutionRequested = true;
     }
-    transform.close();
+    
taskGroupStateManager.onTaskGroupStateChanged(TaskGroupState.State.EXECUTING, 
Optional.empty(), Optional.empty());
+    LOG.info("{} Executing!", taskGroupId);
+
+    // Prepare input data from bounded source.
+    boundedSrcReadStartTime = System.currentTimeMillis();
+    prepareInputFromSource();
+    boundedSrcReadEndTime = System.currentTimeMillis();
+    metric.put("BoundedSourceReadTime(ms)", boundedSrcReadEndTime - 
boundedSrcReadStartTime);
+
+    // Prepare input data from other stages.
+    inputReadStartTime = System.currentTimeMillis();
+    prepareInputFromOtherStages();
+
+    // Execute the TaskGroup DAG.
+    try {
+      srcIteratorIdToDataHandlersMap.forEach((srcIteratorId, dataHandlers) -> {
+        Iterator iterator = idToSrcIteratorMap.get(srcIteratorId);
+        iterator.forEachRemaining(element -> {
+          for (final TaskDataHandler dataHandler : dataHandlers) {
+            runTask(dataHandler, element);
+          }
+        });
+      });
 
-    metric.put("InputReadTime(ms)", readFutureEndTime - readStartTime + 
accumulatedBlockedReadTime);
-    final long transformEndTime = System.currentTimeMillis();
-    metric.put("TransformTime(ms)",
-        transformEndTime - readFutureEndTime - accumulatedWriteTime - 
accumulatedBlockedReadTime);
+      // Process data from other stages.
+      for (int currPartition = 0; currPartition < numPartitions; 
currPartition++) {
+        Pair<String, DataUtil.IteratorWithNumBytes> idToIteratorPair = 
partitionQueue.take();
+        final String iteratorId = idToIteratorPair.left();
+        final DataUtil.IteratorWithNumBytes iterator = 
idToIteratorPair.right();
+        List<TaskDataHandler> dataHandlers = 
iteratorIdToDataHandlersMap.get(iteratorId);
+        iterator.forEachRemaining(element -> {
+          for (final TaskDataHandler dataHandler : dataHandlers) {
+            runTask(dataHandler, element);
+          }
+        });
 
-    // Check whether there is any output data from the transform and write the 
output of this task to the writer.
-    final List<Long> writtenBytesList = new ArrayList<>();
-    final List output = outputCollector.collectOutputList();
-    if (physicalTaskIdToOutputWriterMap.containsKey(physicalTaskId)) {
-      for (final OutputWriter outputWriter : 
physicalTaskIdToOutputWriterMap.get(physicalTaskId)) {
-        if (!output.isEmpty()) {
-          outputWriter.write(output);
+        // Collect metrics on block size if possible.
+        try {
+          serBlockSize += iterator.getNumSerializedBytes();
+        } catch (final 
DataUtil.IteratorWithNumBytes.NumBytesNotSupportedException e) {
+          serBlockSize = -1;
+        } catch (final IllegalStateException e) {
 
 Review comment:
   When it throws `IllegalStateException`?

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
us...@infra.apache.org


With regards,
Apache Git Services

Reply via email to