org.apache.flink.shaded.jackson2.com.fasterxml.jackson.annotation.JsonProperty Java Examples

The following examples show how to use org.apache.flink.shaded.jackson2.com.fasterxml.jackson.annotation.JsonProperty. You can vote up the ones you like or vote down the ones you don't like, and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: ClusterOverviewWithVersion.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public ClusterOverviewWithVersion(
		@JsonProperty(FIELD_NAME_TASKMANAGERS) int numTaskManagersConnected,
		@JsonProperty(FIELD_NAME_SLOTS_TOTAL) int numSlotsTotal,
		@JsonProperty(FIELD_NAME_SLOTS_AVAILABLE) int numSlotsAvailable,
		@JsonProperty(FIELD_NAME_JOBS_RUNNING) int numJobsRunningOrPending,
		@JsonProperty(FIELD_NAME_JOBS_FINISHED) int numJobsFinished,
		@JsonProperty(FIELD_NAME_JOBS_CANCELLED) int numJobsCancelled,
		@JsonProperty(FIELD_NAME_JOBS_FAILED) int numJobsFailed,
		@JsonProperty(FIELD_NAME_VERSION) String version,
		@JsonProperty(FIELD_NAME_COMMIT) String commitId) {
	super(
		numTaskManagersConnected,
		numSlotsTotal,
		numSlotsAvailable,
		numJobsRunningOrPending,
		numJobsFinished,
		numJobsCancelled,
		numJobsFailed);

	this.version = Preconditions.checkNotNull(version);
	this.commitId = Preconditions.checkNotNull(commitId);
}
 
Example #2
Source File: ClusterOverviewWithVersion.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public ClusterOverviewWithVersion(
		@JsonProperty(FIELD_NAME_TASKMANAGERS) int numTaskManagersConnected,
		@JsonProperty(FIELD_NAME_SLOTS_TOTAL) int numSlotsTotal,
		@JsonProperty(FIELD_NAME_SLOTS_AVAILABLE) int numSlotsAvailable,
		@JsonProperty(FIELD_NAME_JOBS_RUNNING) int numJobsRunningOrPending,
		@JsonProperty(FIELD_NAME_JOBS_FINISHED) int numJobsFinished,
		@JsonProperty(FIELD_NAME_JOBS_CANCELLED) int numJobsCancelled,
		@JsonProperty(FIELD_NAME_JOBS_FAILED) int numJobsFailed,
		@JsonProperty(FIELD_NAME_VERSION) String version,
		@JsonProperty(FIELD_NAME_COMMIT) String commitId) {
	super(
		numTaskManagersConnected,
		numSlotsTotal,
		numSlotsAvailable,
		numJobsRunningOrPending,
		numJobsFinished,
		numJobsCancelled,
		numJobsFailed);

	this.version = Preconditions.checkNotNull(version);
	this.commitId = Preconditions.checkNotNull(commitId);
}
 
Example #3
Source File: TaskManagerDetailsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskManagerDetailsInfo(
		@JsonDeserialize(using = ResourceIDDeserializer.class) @JsonProperty(FIELD_NAME_RESOURCE_ID) ResourceID resourceId,
		@JsonProperty(FIELD_NAME_ADDRESS) String address,
		@JsonProperty(FIELD_NAME_DATA_PORT) int dataPort,
		@JsonProperty(FIELD_NAME_LAST_HEARTBEAT) long lastHeartbeat,
		@JsonProperty(FIELD_NAME_NUMBER_SLOTS) int numberSlots,
		@JsonProperty(FIELD_NAME_NUMBER_AVAILABLE_SLOTS) int numberAvailableSlots,
		@JsonProperty(FIELD_NAME_HARDWARE) HardwareDescription hardwareDescription,
		@JsonProperty(FIELD_NAME_METRICS) TaskManagerMetricsInfo taskManagerMetrics) {
	super(
		resourceId,
		address,
		dataPort,
		lastHeartbeat,
		numberSlots,
		numberAvailableSlots,
		hardwareDescription);

	this.taskManagerMetrics = Preconditions.checkNotNull(taskManagerMetrics);
}
 
Example #4
Source File: TaskManagerInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskManagerInfo(
		@JsonDeserialize(using = ResourceIDDeserializer.class) @JsonProperty(FIELD_NAME_RESOURCE_ID) ResourceID resourceId,
		@JsonProperty(FIELD_NAME_ADDRESS) String address,
		@JsonProperty(FIELD_NAME_DATA_PORT) int dataPort,
		@JsonProperty(FIELD_NAME_LAST_HEARTBEAT) long lastHeartbeat,
		@JsonProperty(FIELD_NAME_NUMBER_SLOTS) int numberSlots,
		@JsonProperty(FIELD_NAME_NUMBER_AVAILABLE_SLOTS) int numberAvailableSlots,
		@JsonProperty(FIELD_NAME_HARDWARE) HardwareDescription hardwareDescription) {
	this.resourceId = Preconditions.checkNotNull(resourceId);
	this.address = Preconditions.checkNotNull(address);
	this.dataPort = dataPort;
	this.lastHeartbeat = lastHeartbeat;
	this.numberSlots = numberSlots;
	this.numberAvailableSlots = numberAvailableSlots;
	this.hardwareDescription = Preconditions.checkNotNull(hardwareDescription);
}
 
Example #5
Source File: JobSubmitRequestBody.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public JobSubmitRequestBody(
		@Nullable @JsonProperty(FIELD_NAME_JOB_GRAPH) String jobGraphFileName,
		@Nullable @JsonProperty(FIELD_NAME_JOB_JARS) Collection<String> jarFileNames,
		@Nullable @JsonProperty(FIELD_NAME_JOB_ARTIFACTS) Collection<DistributedCacheFile> artifactFileNames) {
	this.jobGraphFileName = jobGraphFileName;
	if (jarFileNames == null) {
		this.jarFileNames = Collections.emptyList();
	} else {
		this.jarFileNames = jarFileNames;
	}
	if (artifactFileNames == null) {
		this.artifactFileNames = Collections.emptyList();
	} else {
		this.artifactFileNames = artifactFileNames;
	}
}
 
Example #6
Source File: JobVertexDetailsInfo.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public VertexTaskDetail(
		@JsonProperty(FIELD_NAME_SUBTASK) int subtask,
		@JsonProperty(FIELD_NAME_STATUS) ExecutionState status,
		@JsonProperty(FIELD_NAME_ATTEMPT) int attempt,
		@JsonProperty(FIELD_NAME_HOST) String host,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_METRICS) IOMetricsInfo metrics) {
	this.subtask = subtask;
	this.status = checkNotNull(status);
	this.attempt = attempt;
	this.host = checkNotNull(host);
	this.startTime = startTime;
	this.startTimeCompatible = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.metrics = checkNotNull(metrics);
}
 
Example #7
Source File: TaskCheckpointStatisticsWithSubtaskDetails.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskCheckpointStatisticsWithSubtaskDetails(
		@JsonProperty(FIELD_NAME_ID) long checkpointId,
		@JsonProperty(FIELD_NAME_CHECKPOINT_STATUS) CheckpointStatsStatus checkpointStatus,
		@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
		@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
		@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
		@JsonProperty(FIELD_NAME_SUMMARY) Summary summary,
		@JsonProperty(FIELD_NAME_SUBTASKS_CHECKPOINT_STATISTICS) List<SubtaskCheckpointStatistics> subtaskCheckpointStatistics) {
	super(
		checkpointId,
		checkpointStatus,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks);

	this.summary = Preconditions.checkNotNull(summary);
	this.subtaskCheckpointStatistics = Preconditions.checkNotNull(subtaskCheckpointStatistics);
}
 
Example #8
Source File: CheckpointStatistics.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public PendingCheckpointStatistics(
	@JsonProperty(FIELD_NAME_ID) long id,
	@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
	@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
	@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
	@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
	@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
	@JsonProperty(FIELD_NAME_DURATION) long duration,
	@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
	@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
	@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
	@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointingStatisticsPerTask) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);
}
 
Example #9
Source File: SubtaskExecutionAttemptDetailsInfo.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public SubtaskExecutionAttemptDetailsInfo(
		@JsonProperty(FIELD_NAME_SUBTASK_INDEX) int subtaskIndex,
		@JsonProperty(FIELD_NAME_STATUS) ExecutionState status,
		@JsonProperty(FIELD_NAME_ATTEMPT) int attempt,
		@JsonProperty(FIELD_NAME_HOST) String host,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_METRICS) IOMetricsInfo ioMetricsInfo) {

	this.subtaskIndex = subtaskIndex;
	this.status = Preconditions.checkNotNull(status);
	this.attempt = attempt;
	this.host = Preconditions.checkNotNull(host);
	this.startTime = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.ioMetricsInfo = Preconditions.checkNotNull(ioMetricsInfo);
}
 
Example #10
Source File: CheckpointStatistics.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public PendingCheckpointStatistics(
	@JsonProperty(FIELD_NAME_ID) long id,
	@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
	@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
	@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
	@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
	@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
	@JsonProperty(FIELD_NAME_DURATION) long duration,
	@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
	@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
	@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
	@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointingStatisticsPerTask) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);
}
 
Example #11
Source File: JobDetailsInfo.java    From flink with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public JobVertexDetailsInfo(
		@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(FIELD_NAME_JOB_VERTEX_ID) JobVertexID jobVertexID,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_NAME) String name,
		@JsonProperty(FIELD_NAME_PARALLELISM) int parallelism,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_STATE) ExecutionState executionState,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_DURATION) long duration,
		@JsonProperty(FIELD_NAME_TASKS_PER_STATE) Map<ExecutionState, Integer> tasksPerState,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_METRICS) IOMetricsInfo jobVertexMetrics) {
	this.jobVertexID = Preconditions.checkNotNull(jobVertexID);
	this.name = Preconditions.checkNotNull(name);
	this.parallelism = parallelism;
	this.executionState = Preconditions.checkNotNull(executionState);
	this.startTime = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.tasksPerState = Preconditions.checkNotNull(tasksPerState);
	this.jobVertexMetrics = Preconditions.checkNotNull(jobVertexMetrics);
}
 
Example #12
Source File: TaskCheckpointStatistics.java    From Flink-CEPplus with Apache License 2.0 6 votes vote down vote up
@JsonCreator
public TaskCheckpointStatistics(
		@JsonProperty(FIELD_NAME_ID) long checkpointId,
		@JsonProperty(FIELD_NAME_CHECKPOINT_STATUS) CheckpointStatsStatus checkpointStatus,
		@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
		@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
		@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks) {

	this.checkpointId = checkpointId;
	this.checkpointStatus = Preconditions.checkNotNull(checkpointStatus);
	this.latestAckTimestamp = latestAckTimestamp;
	this.stateSize = stateSize;
	this.duration = duration;
	this.alignmentBuffered = alignmentBuffered;
	this.numSubtasks = numSubtasks;
	this.numAckSubtasks = numAckSubtasks;
}
 
Example #13
Source File: ClusterConfigurationInfoEntry.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public ClusterConfigurationInfoEntry(
		@JsonProperty(FIELD_NAME_CONFIG_KEY) String key,
		@JsonProperty(FIELD_NAME_CONFIG_VALUE) String value) {
	this.key = Preconditions.checkNotNull(key);
	this.value = Preconditions.checkNotNull(value);
}
 
Example #14
Source File: CheckpointingStatistics.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public LatestCheckpoints(
		@JsonProperty(FIELD_NAME_COMPLETED) @Nullable CheckpointStatistics.CompletedCheckpointStatistics completedCheckpointStatistics,
		@JsonProperty(FIELD_NAME_SAVEPOINT) @Nullable CheckpointStatistics.CompletedCheckpointStatistics savepointStatistics,
		@JsonProperty(FIELD_NAME_FAILED) @Nullable CheckpointStatistics.FailedCheckpointStatistics failedCheckpointStatistics,
		@JsonProperty(FIELD_NAME_RESTORED) @Nullable RestoredCheckpointStatistics restoredCheckpointStatistics) {
	this.completedCheckpointStatistics = completedCheckpointStatistics;
	this.savepointStatistics = savepointStatistics;
	this.failedCheckpointStatistics = failedCheckpointStatistics;
	this.restoredCheckpointStatistics = restoredCheckpointStatistics;
}
 
Example #15
Source File: CheckpointingStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public Counts(
		@JsonProperty(FIELD_NAME_RESTORED_CHECKPOINTS) long numberRestoredCheckpoints,
		@JsonProperty(FIELD_NAME_TOTAL_CHECKPOINTS) long totalNumberCheckpoints,
		@JsonProperty(FIELD_NAME_IN_PROGRESS_CHECKPOINTS) int numberInProgressCheckpoints,
		@JsonProperty(FIELD_NAME_COMPLETED_CHECKPOINTS) long numberCompletedCheckpoints,
		@JsonProperty(FIELD_NAME_FAILED_CHECKPOINTS) long numberFailedCheckpoints) {
	this.numberRestoredCheckpoints = numberRestoredCheckpoints;
	this.totalNumberCheckpoints = totalNumberCheckpoints;
	this.numberInProgressCheckpoints = numberInProgressCheckpoints;
	this.numberCompletedCheckpoints = numberCompletedCheckpoints;
	this.numberFailedCheckpoints = numberFailedCheckpoints;
}
 
Example #16
Source File: JobVertexTaskManagersInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexTaskManagersInfo(
		@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(VERTEX_TASK_FIELD_ID) JobVertexID jobVertexID,
		@JsonProperty(VERTEX_TASK_FIELD_NAME) String name,
		@JsonProperty(VERTEX_TASK_FIELD_NOW) long now,
		@JsonProperty(VERTEX_TASK_FIELD_TASK_MANAGERS) Collection<TaskManagersInfo> taskManagerInfos) {
	this.jobVertexID = checkNotNull(jobVertexID);
	this.name = checkNotNull(name);
	this.now = now;
	this.taskManagerInfos = checkNotNull(taskManagerInfos);
}
 
Example #17
Source File: JobVertexBackPressureInfo.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexBackPressureInfo(
	@JsonProperty(FIELD_NAME_STATUS) VertexBackPressureStatus status,
	@JsonProperty(FIELD_NAME_BACKPRESSURE_LEVEL) VertexBackPressureLevel backpressureLevel,
	@JsonProperty(FIELD_NAME_END_TIMESTAMP) Long endTimestamp,
	@JsonProperty(FIELD_NAME_SUBTASKS) List<SubtaskBackPressureInfo> subtasks) {
	this.status = status;
	this.backpressureLevel = backpressureLevel;
	this.endTimestamp = endTimestamp;
	this.subtasks = subtasks;
}
 
Example #18
Source File: RestServerEndpointITCase.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public TestRequest(
		@JsonProperty("id") int id,
		@JsonProperty("content") final String content) {
	this.id = id;
	this.content = content;
}
 
Example #19
Source File: JobVertexBackPressureInfo.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
public SubtaskBackPressureInfo(
	@JsonProperty(FIELD_NAME_SUBTASK) int subtask,
	@JsonProperty(FIELD_NAME_BACKPRESSURE_LEVEL) VertexBackPressureLevel backpressureLevel,
	@JsonProperty(FIELD_NAME_RATIO) double ratio) {
	this.subtask = subtask;
	this.backpressureLevel = checkNotNull(backpressureLevel);
	this.ratio = ratio;
}
 
Example #20
Source File: JobDetailsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobDetailsInfo(
		@JsonDeserialize(using = JobIDDeserializer.class) @JsonProperty(FIELD_NAME_JOB_ID) JobID jobId,
		@JsonProperty(FIELD_NAME_JOB_NAME) String name,
		@JsonProperty(FIELD_NAME_IS_STOPPABLE) boolean isStoppable,
		@JsonProperty(FIELD_NAME_JOB_STATUS) JobStatus jobStatus,
		@JsonProperty(FIELD_NAME_START_TIME) long startTime,
		@JsonProperty(FIELD_NAME_END_TIME) long endTime,
		@JsonProperty(FIELD_NAME_DURATION) long duration,
		@JsonProperty(FIELD_NAME_NOW) long now,
		@JsonProperty(FIELD_NAME_TIMESTAMPS) Map<JobStatus, Long> timestamps,
		@JsonProperty(FIELD_NAME_JOB_VERTEX_INFOS) Collection<JobVertexDetailsInfo> jobVertexInfos,
		@JsonProperty(FIELD_NAME_JOB_VERTICES_PER_STATE) Map<ExecutionState, Integer> jobVerticesPerState,
		@JsonProperty(FIELD_NAME_JSON_PLAN) @JsonDeserialize(using = RawJsonDeserializer.class) String jsonPlan) {
	this.jobId = Preconditions.checkNotNull(jobId);
	this.name = Preconditions.checkNotNull(name);
	this.isStoppable = isStoppable;
	this.jobStatus = Preconditions.checkNotNull(jobStatus);
	this.startTime = startTime;
	this.endTime = endTime;
	this.duration = duration;
	this.now = now;
	this.timestamps = Preconditions.checkNotNull(timestamps);
	this.jobVertexInfos = Preconditions.checkNotNull(jobVertexInfos);
	this.jobVerticesPerState = Preconditions.checkNotNull(jobVerticesPerState);
	this.jsonPlan = Preconditions.checkNotNull(jsonPlan);
}
 
Example #21
Source File: JarListInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JarEntryInfo(
		@JsonProperty(JAR_ENTRY_FIELD_NAME) String name,
		@JsonProperty(JAR_ENTRY_FIELD_DESC) @Nullable String description) {
	this.name = checkNotNull(name);
	this.description = description;
}
 
Example #22
Source File: JarListInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JarListInfo(
		@JsonProperty(JAR_LIST_FIELD_ADDRESS) String address,
		@JsonProperty(JAR_LIST_FIELD_FILES) List<JarFileInfo> jarFileList) {
	this.address = checkNotNull(address);
	this.jarFileList = checkNotNull(jarFileList);
}
 
Example #23
Source File: JobVertexDetailsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexDetailsInfo(
		@JsonDeserialize(using = JobVertexIDDeserializer.class) @JsonProperty(FIELD_NAME_VERTEX_ID) JobVertexID id,
		@JsonProperty(FIELD_NAME_VERTEX_NAME) String name,
		@JsonProperty(FIELD_NAME_PARALLELISM) int parallelism,
		@JsonProperty(FIELD_NAME_NOW) long now,
		@JsonProperty(FIELD_NAME_SUBTASKS) List<VertexTaskDetail> subtasks) {
	this.id = checkNotNull(id);
	this.name = checkNotNull(name);
	this.parallelism = parallelism;
	this.now = now;
	this.subtasks = checkNotNull(subtasks);
}
 
Example #24
Source File: CheckpointStatistics.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public CompletedCheckpointStatistics(
	@JsonProperty(FIELD_NAME_ID) long id,
	@JsonProperty(FIELD_NAME_STATUS) CheckpointStatsStatus status,
	@JsonProperty(FIELD_NAME_IS_SAVEPOINT) boolean savepoint,
	@JsonProperty(FIELD_NAME_TRIGGER_TIMESTAMP) long triggerTimestamp,
	@JsonProperty(FIELD_NAME_LATEST_ACK_TIMESTAMP) long latestAckTimestamp,
	@JsonProperty(FIELD_NAME_STATE_SIZE) long stateSize,
	@JsonProperty(FIELD_NAME_DURATION) long duration,
	@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
	@JsonProperty(FIELD_NAME_NUM_SUBTASKS) int numSubtasks,
	@JsonProperty(FIELD_NAME_NUM_ACK_SUBTASKS) int numAckSubtasks,
	@JsonDeserialize(keyUsing = JobVertexIDKeyDeserializer.class) @JsonProperty(FIELD_NAME_TASKS) Map<JobVertexID, TaskCheckpointStatistics> checkpointingStatisticsPerTask,
	@JsonProperty(FIELD_NAME_EXTERNAL_PATH) @Nullable String externalPath,
	@JsonProperty(FIELD_NAME_DISCARDED) boolean discarded) {
	super(
		id,
		status,
		savepoint,
		triggerTimestamp,
		latestAckTimestamp,
		stateSize,
		duration,
		alignmentBuffered,
		numSubtasks,
		numAckSubtasks,
		checkpointingStatisticsPerTask);

	this.externalPath = externalPath;
	this.discarded = discarded;
}
 
Example #25
Source File: JobVertexAccumulatorsInfo.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobVertexAccumulatorsInfo(
		@JsonProperty(FIELD_NAME_ID) String id,
		@JsonProperty(FIELD_NAME_USER_ACCUMULATORS) Collection<UserAccumulator> userAccumulatorList) {
	this.id = Preconditions.checkNotNull(id);
	this.userAccumulatorList = Preconditions.checkNotNull(userAccumulatorList);
}
 
Example #26
Source File: JarRequestBody.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
JarRequestBody(
	@Nullable @JsonProperty(FIELD_NAME_ENTRY_CLASS) String entryClassName,
	@Nullable @JsonProperty(FIELD_NAME_PROGRAM_ARGUMENTS) String programArguments,
	@Nullable @JsonProperty(FIELD_NAME_PROGRAM_ARGUMENTS_LIST) List<String> programArgumentsList,
	@Nullable @JsonProperty(FIELD_NAME_PARALLELISM) Integer parallelism,
	@Nullable @JsonProperty(FIELD_NAME_JOB_ID) JobID jobId) {
	this.entryClassName = entryClassName;
	this.programArguments = programArguments;
	this.programArgumentsList = programArgumentsList;
	this.parallelism = parallelism;
	this.jobId = jobId;
}
 
Example #27
Source File: JobExecutionResultResponseBody.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public JobExecutionResultResponseBody(
		@JsonProperty(value = "status", required = true) final QueueStatus status,
		@JsonProperty(value = "job-execution-result")
		@JsonDeserialize(using = JobResultDeserializer.class)
		@Nullable final JobResult jobExecutionResult) {
	this.status = requireNonNull(status);
	this.jobExecutionResult = jobExecutionResult;
}
 
Example #28
Source File: JarRequestBody.java    From Flink-CEPplus with Apache License 2.0 5 votes vote down vote up
@JsonCreator
JarRequestBody(
	@Nullable @JsonProperty(FIELD_NAME_ENTRY_CLASS) String entryClassName,
	@Nullable @JsonProperty(FIELD_NAME_PROGRAM_ARGUMENTS) String programArguments,
	@Nullable @JsonProperty(FIELD_NAME_PROGRAM_ARGUMENTS_LIST) List<String> programArgumentsList,
	@Nullable @JsonProperty(FIELD_NAME_PARALLELISM) Integer parallelism,
	@Nullable @JsonProperty(FIELD_NAME_JOB_ID) JobID jobId) {
	this.entryClassName = entryClassName;
	this.programArguments = programArguments;
	this.programArgumentsList = programArgumentsList;
	this.parallelism = parallelism;
	this.jobId = jobId;
}
 
Example #29
Source File: SubtaskCheckpointStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public CheckpointAlignment(
		@JsonProperty(FIELD_NAME_ALIGNMENT_BUFFERED) long alignmentBuffered,
		@JsonProperty(FIELD_NAME_ALIGNMENT_DURATION) long alignmentDuration) {
	this.alignmentBuffered = alignmentBuffered;
	this.alignmentDuration = alignmentDuration;
}
 
Example #30
Source File: MinMaxAvgStatistics.java    From flink with Apache License 2.0 5 votes vote down vote up
@JsonCreator
public MinMaxAvgStatistics(
	@JsonProperty(FIELD_NAME_MINIMUM) long minimum,
	@JsonProperty(FIELD_NAME_MAXIMUM) long maximum,
	@JsonProperty(FIELD_NAME_AVERAGE) long average) {
	this.minimum = minimum;
	this.maximum = maximum;
	this.average = average;
}